Package | Description |
---|---|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.client |
Hazelcast JSR-107 aka JCache implementation
Client Requests
|
com.hazelcast.cache.impl.event |
Event classes to define listenters for JCache other than EntryListener
|
com.hazelcast.cache.impl.merge.entry |
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
|
com.hazelcast.cache.impl.nearcache.impl.record |
Near cache record implementations.
|
com.hazelcast.cache.impl.nearcache.impl.store |
Near cache store implementations.
|
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.record |
Hazelcast JSR-107 aka JCache implementation
Internal record store
|
com.hazelcast.client.cache.impl |
Hazelcast JSR-107 aka JCache implementation client side
|
com.hazelcast.client.impl.client |
This contains the Requests and other DTO's exchanged between client/server
|
com.hazelcast.client.impl.protocol.codec |
Client protocol custom codec implementations
|
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
com.hazelcast.client.impl.protocol.task.multimap |
Client protocol tasks implementations for multi map
|
com.hazelcast.client.impl.protocol.task.replicatedmap |
Client protocol tasks implementations for ReplicatedMap
|
com.hazelcast.client.impl.protocol.template | |
com.hazelcast.client.impl.protocol.util |
Protocol utils
|
com.hazelcast.client.proxy |
This package contains client side proxy implementations of the different Hazelcast data structures
and operation types
|
com.hazelcast.client.spi |
Contains classes/interfaces related to Service Provider Interface
such as ClientProxy , ClientClusterService
|
com.hazelcast.client.spi.impl |
Provides util classes for com.hazelcast.client
|
com.hazelcast.collection.common |
This package contains common classes related to all collections
|
com.hazelcast.collection.impl.collection | |
com.hazelcast.collection.impl.collection.client | |
com.hazelcast.collection.impl.collection.operations | |
com.hazelcast.collection.impl.list |
This package contains IList functionality for Hazelcast.
|
com.hazelcast.collection.impl.list.client | |
com.hazelcast.collection.impl.list.operations | |
com.hazelcast.collection.impl.queue | |
com.hazelcast.collection.impl.queue.client |
This package contains client requests for the IQueue.
|
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.set |
This package contains ISet functionality for Hazelcast.
|
com.hazelcast.collection.impl.txncollection.client | |
com.hazelcast.collection.impl.txncollection.operations | |
com.hazelcast.collection.impl.txnlist.client | |
com.hazelcast.collection.impl.txnqueue | |
com.hazelcast.collection.impl.txnqueue.client | |
com.hazelcast.collection.impl.txnqueue.operations | |
com.hazelcast.collection.impl.txnset.client | |
com.hazelcast.concurrent.atomiclong.client |
This package contains client requests for the IAtomicLong.
This package contains all the client request object to operate on the IAtomicLong that are send by the client. |
com.hazelcast.concurrent.atomicreference |
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference . |
com.hazelcast.concurrent.atomicreference.client |
This package contains client requests for the IAtomicLong.
This package contains all the client request object to operate on the IAtomicLong that are send by the client. |
com.hazelcast.concurrent.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
com.hazelcast.concurrent.lock | |
com.hazelcast.concurrent.lock.client |
This package contains client requests for the ILock.
This package contains all the client requests object to operate on the ILock that are send by the client. |
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.executor.impl.operations |
This package contains operations for the IExecutorService.
|
com.hazelcast.internal.serialization |
Contains the private serialization API + implementation.
|
com.hazelcast.internal.serialization.impl | |
com.hazelcast.internal.serialization.impl.bufferpool |
Contains the logic for the BufferPool.
|
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.client |
Contains client requests for the
IMap |
com.hazelcast.map.impl.event | |
com.hazelcast.map.impl.eviction |
This package contains eviction classes.
|
com.hazelcast.map.impl.mapstore |
Contains map store operations.
|
com.hazelcast.map.impl.mapstore.writebehind |
Package for processing write behind store operations.
|
com.hazelcast.map.impl.mapstore.writethrough |
Package for processing write through store operations.
|
com.hazelcast.map.impl.nearcache | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.proxy |
Contains map proxy implementation and support classes.
|
com.hazelcast.map.impl.query | |
com.hazelcast.map.impl.querycache.event |
This package contains classes for query cache events.
|
com.hazelcast.map.impl.record |
Contains record specific classes.
|
com.hazelcast.map.impl.recordstore | |
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.map.impl.wan |
Contains wan replication event classes
|
com.hazelcast.multimap.impl |
Contains classes for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.client |
Contains client requests for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.txn |
This package contains the Transaction behavior for the Multimap.
|
com.hazelcast.nio |
This package contains classes related to New IO
|
com.hazelcast.partition |
Contains the partition logic for Hazelcast.
|
com.hazelcast.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.query.impl |
Contains the implementation classes of the query functionality.
|
com.hazelcast.replicatedmap.impl |
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally.
|
com.hazelcast.replicatedmap.impl.client |
This package contains classes for client communication on replicated map implementation
|
com.hazelcast.replicatedmap.impl.operation |
This package contains replicated map operations which are executed on remote nodes
|
com.hazelcast.replicatedmap.impl.record |
This package contains the implementation of the backing data storage for the replicated map implementation
|
com.hazelcast.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.ringbuffer.impl.client | |
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.spi |
Provides interfaces/classes for Hazelcast SPI.
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.topic.impl |
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
com.hazelcast.topic.impl.client |
This package contains client requests for the ITopic.
|
com.hazelcast.topic.impl.reliable | |
com.hazelcast.transaction.client |
This package contains client transaction code
|
com.hazelcast.transaction.impl.xa.operations | |
com.hazelcast.util |
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
|
com.hazelcast.web |
Provides Hazelcast-based session replication.
|
com.hazelcast.web.entryprocessor |
Provides Entry Processors used in hazelcast-wm
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCacheRecordStore<R extends CacheRecord,CRM extends SampleableCacheRecordMap<Data,R>> |
Modifier and Type | Field and Description |
---|---|
protected Data |
CacheEntryProcessorEntry.keyData |
Modifier and Type | Field and Description |
---|---|
protected EvictionPolicyEvaluator<Data,R> |
AbstractCacheRecordStore.evictionPolicyEvaluator |
protected EvictionStrategy<Data,R,CRM> |
AbstractCacheRecordStore.evictionStrategy |
Modifier and Type | Method and Description |
---|---|
Data |
CacheEventContext.getDataKey() |
Data |
CacheEventData.getDataKey()
Gets cache entry key as
Data . |
Data |
CacheEventDataImpl.getDataKey() |
Data |
CacheEventContext.getDataOldValue() |
Data |
CacheEventData.getDataOldValue()
Gets the old value of entry as
Data , if available. |
Data |
CacheEventDataImpl.getDataOldValue() |
Data |
CacheEventContext.getDataValue() |
Data |
CacheEventData.getDataValue()
Gets cache entry value as
Data . |
Data |
CacheEventDataImpl.getDataValue() |
Data |
CacheKeyIteratorResult.getKey(int index) |
protected Data |
CacheRecordStore.recordToData(CacheRecord record) |
protected abstract Data |
AbstractCacheRecordStore.recordToData(R record) |
Data |
AbstractCacheService.toData(Object object) |
protected abstract Data |
AbstractClusterWideIterator.toData(Object obj) |
protected Data |
ClusterWideIterator.toData(Object obj) |
protected Data |
AbstractCacheRecordStore.toData(Object obj) |
Data |
AbstractCacheRecordStore.toEventData(Object obj) |
protected Data |
CacheRecordStore.toHeapData(Object obj) |
protected abstract Data |
AbstractCacheRecordStore.toHeapData(Object obj) |
protected Data |
CacheRecordStore.valueToData(Object value) |
protected abstract Data |
AbstractCacheRecordStore.valueToData(Object value) |
Modifier and Type | Method and Description |
---|---|
static CacheEntryView<Data,Data> |
CacheEntryViews.createDefaultEntryView(Data key,
Data value,
CacheRecord record)
Creates a
DefaultCacheEntryView instance. |
static CacheEntryView<Data,Data> |
CacheEntryViews.createDefaultEntryView(Data key,
Data value,
CacheRecord record)
Creates a
DefaultCacheEntryView instance. |
static CacheEntryView<Data,Data> |
CacheEntryViews.createEntryView(Data key,
Data value,
CacheRecord record,
CacheEntryViews.CacheEntryViewType cacheEntryViewType)
Creates a
CacheEntryView instance. |
static CacheEntryView<Data,Data> |
CacheEntryViews.createEntryView(Data key,
Data value,
CacheRecord record,
CacheEntryViews.CacheEntryViewType cacheEntryViewType)
Creates a
CacheEntryView instance. |
protected EvictionPolicyEvaluator<Data,R> |
AbstractCacheRecordStore.createEvictionPolicyEvaluator(EvictionConfig cacheEvictionConfig) |
protected EvictionStrategy<Data,R,CRM> |
AbstractCacheRecordStore.createEvictionStrategy(EvictionConfig cacheEvictionConfig) |
static CacheEntryView<Data,Data> |
CacheEntryViews.createLazyEntryView(Data key,
Data value,
CacheRecord record)
Creates a
LazyCacheEntryView instance. |
static CacheEntryView<Data,Data> |
CacheEntryViews.createLazyEntryView(Data key,
Data value,
CacheRecord record)
Creates a
LazyCacheEntryView instance. |
List<Data> |
CacheKeyIteratorResult.getKeys() |
Map<Data,CacheRecord> |
ICacheRecordStore.getReadOnlyRecords()
Returns a readonly map of the internal key value store.
|
Map<Data,CacheRecord> |
AbstractCacheRecordStore.getReadOnlyRecords() |
Set<Data> |
ICacheRecordStore.loadAll(Set<Data> keys,
boolean replaceExistingValues)
Synchronously loads the specified entries into the cache using the
configured
CacheLoader for the given keys. |
Set<Data> |
AbstractCacheRecordStore.loadAll(Set<Data> keys,
boolean replaceExistingValues) |
protected Map<Data,Object> |
AbstractCacheRecordStore.loadAllCacheEntry(Set<Data> keys) |
Modifier and Type | Method and Description |
---|---|
R |
AbstractCacheRecordStore.accessRecord(Data key,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now) |
boolean |
ICacheRecordStore.contains(Data key)
Determines if this store contains an entry for the specified key.
|
boolean |
AbstractCacheRecordStore.contains(Data key) |
static CacheEventContext |
CacheEventContextUtil.createBaseEventContext(CacheEventType eventType,
Data dataKey,
Data dataValue,
long expirationTime,
String origin,
int completionId) |
static CacheEventContext |
CacheEventContextUtil.createCacheCompleteEvent(Data dataKey,
int completionId) |
static CacheEventContext |
CacheEventContextUtil.createCacheCompleteEvent(Data dataKey,
long expirationTime,
String origin,
int completionId) |
static CacheEventContext |
CacheEventContextUtil.createCacheCreatedEvent(Data dataKey,
Data dataValue,
long expirationTime,
String origin,
int completionId) |
protected CacheEntryProcessorEntry |
CacheRecordStore.createCacheEntryProcessorEntry(Data key,
CacheRecord record,
long now,
int completionId) |
protected abstract CacheEntryProcessorEntry |
AbstractCacheRecordStore.createCacheEntryProcessorEntry(Data key,
R record,
long now,
int completionId) |
static CacheEventContext |
CacheEventContextUtil.createCacheExpiredEvent(Data dataKey,
Data dataValue,
long expirationTime,
String origin,
int completionId) |
static CacheEventContext |
CacheEventContextUtil.createCacheRemovedEvent(Data dataKey) |
static CacheEventContext |
CacheEventContextUtil.createCacheRemovedEvent(Data dataKey,
Data dataValue,
long expirationTime,
String origin,
int completionId) |
static CacheEventContext |
CacheEventContextUtil.createCacheUpdatedEvent(Data dataKey,
Data dataValue,
Data dataOldValue,
long expirationTime,
long lastAccessTime,
long accessHit) |
static CacheEventContext |
CacheEventContextUtil.createCacheUpdatedEvent(Data dataKey,
Data dataValue,
Data dataOldValue,
long expirationTime,
long lastAccessTime,
long accessHit,
String origin,
int completionId) |
Operation |
CacheOperationProvider.createContainsKeyOperation(Data key) |
Operation |
DefaultOperationProvider.createContainsKeyOperation(Data key) |
static CacheEntryView<Data,Data> |
CacheEntryViews.createDefaultEntryView(Data key,
Data value,
CacheRecord record)
Creates a
DefaultCacheEntryView instance. |
Operation |
CacheOperationProvider.createEntryProcessorOperation(Data key,
Integer completionId,
javax.cache.processor.EntryProcessor entryProcessor,
Object... args) |
Operation |
DefaultOperationProvider.createEntryProcessorOperation(Data key,
Integer completionId,
javax.cache.processor.EntryProcessor entryProcessor,
Object... arguments) |
static CacheEntryView<Data,Data> |
CacheEntryViews.createEntryView(Data key,
Data value,
CacheRecord record,
CacheEntryViews.CacheEntryViewType cacheEntryViewType)
Creates a
CacheEntryView instance. |
Operation |
CacheOperationProvider.createGetAndRemoveOperation(Data key,
int completionId) |
Operation |
DefaultOperationProvider.createGetAndRemoveOperation(Data key,
int completionId) |
Operation |
CacheOperationProvider.createGetAndReplaceOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createGetAndReplaceOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createGetOperation(Data key,
javax.cache.expiry.ExpiryPolicy policy) |
Operation |
DefaultOperationProvider.createGetOperation(Data key,
javax.cache.expiry.ExpiryPolicy policy) |
static CacheEntryView<Data,Data> |
CacheEntryViews.createLazyEntryView(Data key,
Data value,
CacheRecord record)
Creates a
LazyCacheEntryView instance. |
Operation |
CacheOperationProvider.createPutIfAbsentOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createPutIfAbsentOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createPutOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
boolean get,
int completionId) |
Operation |
DefaultOperationProvider.createPutOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
boolean get,
int completionId) |
protected R |
AbstractCacheRecordStore.createRecord(Data keyData,
Object value,
long expirationTime,
int completionId) |
protected R |
AbstractCacheRecordStore.createRecord(Data key,
Object value,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId,
String origin) |
protected R |
AbstractCacheRecordStore.createRecordWithExpiry(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId) |
protected R |
AbstractCacheRecordStore.createRecordWithExpiry(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId,
String origin) |
protected R |
AbstractCacheRecordStore.createRecordWithExpiry(Data key,
Object value,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId) |
protected R |
AbstractCacheRecordStore.createRecordWithExpiry(Data key,
Object value,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId,
String origin) |
Operation |
CacheOperationProvider.createRemoveOperation(Data key,
Data value,
int completionId) |
Operation |
DefaultOperationProvider.createRemoveOperation(Data key,
Data oldValue,
int completionId) |
Operation |
CacheOperationProvider.createReplaceOperation(Data key,
Data oldValue,
Data newValue,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createReplaceOperation(Data key,
Data oldValue,
Data newValue,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
protected Object |
CacheRecordStore.dataToValue(Data data) |
protected abstract Object |
AbstractCacheRecordStore.dataToValue(Data data) |
protected void |
AbstractCacheRecordStore.deleteCacheEntry(Data key) |
protected boolean |
AbstractCacheRecordStore.deleteRecord(Data key,
int completionId) |
protected boolean |
AbstractCacheRecordStore.deleteRecord(Data key,
int completionId,
String source) |
protected boolean |
AbstractCacheRecordStore.deleteRecord(Data key,
int completionId,
String source,
String origin) |
R |
AbstractCacheRecordStore.doPutRecord(Data key,
R record) |
protected R |
AbstractCacheRecordStore.doPutRecord(Data key,
R record,
String source) |
protected R |
AbstractCacheRecordStore.doRemoveRecord(Data key) |
protected R |
AbstractCacheRecordStore.doRemoveRecord(Data key,
String source) |
Object |
ICacheRecordStore.get(Data key,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Gets the value to which the specified key is mapped,
or
null if this cache contains no mapping for the key. |
Object |
AbstractCacheRecordStore.get(Data key,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
Object |
ICacheRecordStore.getAndPut(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId)
Associates the specified value with the specified key in this cache,
returning an existing value if one existed.
|
Object |
AbstractCacheRecordStore.getAndPut(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
int completionId) |
Object |
ICacheRecordStore.getAndRemove(Data key,
String caller,
int completionId)
Atomically removes the entry for a key only if it is currently mapped to some
value.
|
Object |
AbstractCacheRecordStore.getAndRemove(Data key,
String source,
int completionId) |
Object |
AbstractCacheRecordStore.getAndRemove(Data key,
String source,
int completionId,
String origin) |
Object |
ICacheRecordStore.getAndReplace(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId)
Atomically replaces the value for a given key if and only if there is a
value currently mapped by the key.
|
Object |
AbstractCacheRecordStore.getAndReplace(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
int completionId) |
static int |
CacheProxyUtil.getPartitionId(NodeEngine nodeEngine,
Data key) |
CacheRecord |
ICacheRecordStore.getRecord(Data key)
Gets internal record of the store by key.
|
CacheRecord |
AbstractCacheRecordStore.getRecord(Data key) |
protected void |
AbstractCacheRecordStore.invalidateEntry(Data key) |
protected void |
AbstractCacheRecordStore.invalidateEntry(Data key,
String source) |
Object |
ICacheRecordStore.invoke(Data key,
javax.cache.processor.EntryProcessor entryProcessor,
Object[] arguments,
int completionId)
Invokes an
EntryProcessor against the Cache.Entry specified by
the provided key. |
Object |
AbstractCacheRecordStore.invoke(Data key,
javax.cache.processor.EntryProcessor entryProcessor,
Object[] arguments,
int completionId) |
protected void |
CacheEntryProcessorEntry.onCreate(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId,
boolean saved) |
protected void |
AbstractCacheRecordStore.onCreateRecordError(Data key,
Object value,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId,
String origin,
R record,
Throwable error) |
protected void |
AbstractCacheRecordStore.onDeleteRecord(Data key,
R record,
Data dataValue,
boolean deleted) |
protected void |
AbstractCacheRecordStore.onDeleteRecordError(Data key,
R record,
Data dataValue,
boolean deleted,
Throwable error) |
void |
AbstractCacheRecordStore.onEvict(Data key,
R record) |
protected void |
AbstractCacheRecordStore.onGet(Data key,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
Object value,
R record) |
protected void |
AbstractCacheRecordStore.onGetError(Data key,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
Object value,
R record,
Throwable error) |
protected void |
CacheEntryProcessorEntry.onLoad(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId,
boolean saved) |
protected void |
AbstractCacheRecordStore.onProcessExpiredEntry(Data key,
R record,
long expiryTime,
long now,
String source,
String origin) |
protected void |
AbstractCacheRecordStore.onPut(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean getValue,
boolean disableWriteThrough,
R record,
Object oldValue,
boolean isExpired,
boolean isNewPut,
boolean isSaveSucceed) |
protected void |
AbstractCacheRecordStore.onPutError(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean getValue,
boolean disableWriteThrough,
R record,
Object oldValue,
boolean wouldBeNewPut,
Throwable error) |
protected void |
AbstractCacheRecordStore.onPutIfAbsent(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean disableWriteThrough,
R record,
boolean isExpired,
boolean isSaveSucceed) |
protected void |
AbstractCacheRecordStore.onPutIfAbsentError(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean disableWriteThrough,
R record,
Throwable error) |
protected long |
AbstractCacheRecordStore.onRecordAccess(Data key,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now) |
protected void |
AbstractCacheRecordStore.onRemove(Data key,
Object value,
String source,
boolean getValue,
R record,
boolean removed) |
protected void |
CacheEntryProcessorEntry.onRemove(Data key,
String source,
int completionId,
boolean removed) |
protected void |
AbstractCacheRecordStore.onRemoveError(Data key,
Object value,
String source,
boolean getValue,
R record,
boolean removed,
Throwable error) |
protected void |
AbstractCacheRecordStore.onReplace(Data key,
Object oldValue,
Object newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean getValue,
R record,
boolean isExpired,
boolean replaced) |
protected void |
AbstractCacheRecordStore.onReplaceError(Data key,
Object oldValue,
Object newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean getValue,
R record,
boolean isExpired,
boolean replaced,
Throwable error) |
protected void |
CacheEntryProcessorEntry.onUpdate(Data key,
Object value,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId,
boolean saved) |
protected void |
AbstractCacheRecordStore.onUpdateRecord(Data key,
R record,
Object value,
Data oldDataValue) |
protected void |
AbstractCacheRecordStore.onUpdateRecordError(Data key,
R record,
Object value,
Data newDataValue,
Data oldDataValue,
Throwable error) |
protected boolean |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long now) |
protected R |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long expiryTime,
long now,
String source) |
protected R |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long expiryTime,
long now,
String source,
String origin) |
protected boolean |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long now,
String source) |
protected boolean |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long now,
String source,
String origin) |
protected Object |
AbstractCacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean getValue,
boolean disableWriteThrough,
int completionId) |
protected Object |
AbstractCacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean getValue,
int completionId) |
CacheRecord |
ICacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId)
Associates the specified value with the specified key in this cache,
returning an existing value if one existed.
|
R |
AbstractCacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
int completionId) |
protected boolean |
AbstractCacheRecordStore.putIfAbsent(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
boolean disableWriteThrough,
int completionId) |
boolean |
ICacheRecordStore.putIfAbsent(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId)
Removes the mapping for a key from this cache if it is present.
|
boolean |
AbstractCacheRecordStore.putIfAbsent(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
int completionId) |
void |
ICacheRecordStore.putRecord(Data key,
CacheRecord record)
Associates the specified record with the specified key.
|
void |
AbstractCacheRecordStore.putRecord(Data key,
CacheRecord record) |
Object |
AbstractCacheRecordStore.readThroughCache(Data key) |
R |
AbstractCacheRecordStore.readThroughRecord(Data key,
long now) |
boolean |
ICacheRecordStore.remove(Data key,
Object value,
String caller,
int completionId)
Atomically removes the mapping for a key only if currently mapped to the
given value.
|
boolean |
AbstractCacheRecordStore.remove(Data key,
Object value,
String source,
int completionId) |
boolean |
AbstractCacheRecordStore.remove(Data key,
Object value,
String source,
int completionId,
String origin) |
boolean |
ICacheRecordStore.remove(Data key,
String caller,
int completionId)
Removes the mapping for a key from this cache if it is present.
|
boolean |
AbstractCacheRecordStore.remove(Data key,
String source,
int completionId) |
boolean |
AbstractCacheRecordStore.remove(Data key,
String source,
int completionId,
String origin) |
CacheRecord |
ICacheRecordStore.removeRecord(Data key)
Removes the record for a key.
|
CacheRecord |
AbstractCacheRecordStore.removeRecord(Data key) |
boolean |
ICacheRecordStore.replace(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId)
Atomically replaces the entry for a key only if currently mapped to some
value.
|
boolean |
AbstractCacheRecordStore.replace(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
int completionId) |
boolean |
ICacheRecordStore.replace(Data key,
Object oldValue,
Object newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId)
Atomically replaces the entry for a key only if currently mapped to a
given value.
|
boolean |
AbstractCacheRecordStore.replace(Data key,
Object oldValue,
Object newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String source,
int completionId) |
void |
AbstractCacheService.sendInvalidationEvent(String name,
Data key,
String sourceUuid)
Sends an invalidation event for given
cacheName with specified key
from mentioned source with sourceUuid . |
void |
ICacheService.sendInvalidationEvent(String name,
Data key,
String sourceUuid) |
CacheEventContext |
CacheEventContext.setDataKey(Data dataKey) |
CacheEventContext |
CacheEventContext.setDataOldValue(Data dataOldValue) |
CacheEventContext |
CacheEventContext.setDataValue(Data dataValue) |
protected long |
AbstractCacheRecordStore.updateAccessDuration(Data key,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now) |
protected void |
AbstractCacheRecordStore.updateRecord(Data key,
R record,
Object value,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId,
String source,
String origin) |
protected boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId) |
protected boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId,
String source) |
protected boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId,
String source,
String origin) |
protected boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId) |
protected boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId,
String source) |
protected boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
long expiryTime,
long now,
boolean disableWriteThrough,
int completionId,
String source,
String origin) |
void |
AbstractCacheRecordStore.writeThroughCache(Data key,
Object value) |
Modifier and Type | Method and Description |
---|---|
OperationFactory |
CacheOperationProvider.createGetAllOperationFactory(Set<Data> keySet,
javax.cache.expiry.ExpiryPolicy policy) |
OperationFactory |
DefaultOperationProvider.createGetAllOperationFactory(Set<Data> keySet,
javax.cache.expiry.ExpiryPolicy policy) |
OperationFactory |
CacheOperationProvider.createLoadAllOperationFactory(Set<Data> keySet,
boolean replaceExistingValues) |
OperationFactory |
DefaultOperationProvider.createLoadAllOperationFactory(Set<Data> keySet,
boolean replaceExistingValues) |
Operation |
CacheOperationProvider.createPutAllOperation(List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createPutAllOperation(List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createPutAllOperation(List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createPutAllOperation(List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
OperationFactory |
CacheOperationProvider.createRemoveAllOperationFactory(Set<Data> keySet,
Integer completionId) |
OperationFactory |
DefaultOperationProvider.createRemoveAllOperationFactory(Set<Data> keySet,
Integer completionId) |
protected void |
AbstractCacheRecordStore.deleteAllCacheEntry(Set<Data> keys) |
MapEntries |
ICacheRecordStore.getAll(Set<Data> keySet,
javax.cache.expiry.ExpiryPolicy expiryPolicy)
Gets a collection of entries from the store, returning them as
Map of the values associated with the set of keys requested. |
MapEntries |
AbstractCacheRecordStore.getAll(Set<Data> keySet,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
Set<Data> |
ICacheRecordStore.loadAll(Set<Data> keys,
boolean replaceExistingValues)
Synchronously loads the specified entries into the cache using the
configured
CacheLoader for the given keys. |
Set<Data> |
AbstractCacheRecordStore.loadAll(Set<Data> keys,
boolean replaceExistingValues) |
protected Map<Data,Object> |
AbstractCacheRecordStore.loadAllCacheEntry(Set<Data> keys) |
CacheRecord |
SplitBrainAwareCacheRecordStore.merge(CacheEntryView<Data,Data> cacheEntryView,
CacheMergePolicy mergePolicy)
Merges given record (inside given
CacheEntryView ) with the existing record as given CacheMergePolicy . |
CacheRecord |
SplitBrainAwareCacheRecordStore.merge(CacheEntryView<Data,Data> cacheEntryView,
CacheMergePolicy mergePolicy)
Merges given record (inside given
CacheEntryView ) with the existing record as given CacheMergePolicy . |
CacheRecord |
CacheRecordStore.merge(CacheEntryView<Data,Data> cacheEntryView,
CacheMergePolicy mergePolicy) |
CacheRecord |
CacheRecordStore.merge(CacheEntryView<Data,Data> cacheEntryView,
CacheMergePolicy mergePolicy) |
void |
ICacheRecordStore.removeAll(Set<Data> keys,
int completionId)
records of keys will be deleted one by one and will publish a REMOVE event
for each key.
|
void |
AbstractCacheRecordStore.removeAll(Set<Data> keys,
int completionId) |
Constructor and Description |
---|
CacheEntryProcessorEntry(Data keyData,
R record,
AbstractCacheRecordStore cacheRecordStore,
long now,
int completionId) |
CacheEventDataImpl(String name,
CacheEventType eventType,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
boolean isOldValueAvailable) |
Constructor and Description |
---|
CacheKeyIteratorResult(List<Data> keys,
int tableIndex) |
Modifier and Type | Method and Description |
---|---|
Data |
CacheSingleInvalidationMessage.getKey() |
Data |
CacheInvalidationMessage.getKey() |
Modifier and Type | Method and Description |
---|---|
Set<Data> |
CacheLoadAllRequest.getKeys() |
Constructor and Description |
---|
CacheContainsKeyRequest(String name,
Data key,
InMemoryFormat inMemoryFormat) |
CacheEntryProcessorRequest(String name,
Data key,
javax.cache.processor.EntryProcessor entryProcessor,
InMemoryFormat inMemoryFormat,
Object... arguments) |
CacheGetAndRemoveRequest(String name,
Data key,
InMemoryFormat inMemoryFormat) |
CacheGetAndReplaceRequest(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
InMemoryFormat inMemoryFormat) |
CacheGetRequest(String name,
Data key,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
InMemoryFormat inMemoryFormat) |
CachePutIfAbsentRequest(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
InMemoryFormat inMemoryFormat) |
CachePutRequest(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
boolean get,
InMemoryFormat inMemoryFormat) |
CachePutRequest(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
InMemoryFormat inMemoryFormat) |
CachePutRequest(String name,
Data key,
Data value,
InMemoryFormat inMemoryFormat) |
CacheRemoveRequest(String name,
Data key,
Data currentValue,
InMemoryFormat inMemoryFormat) |
CacheRemoveRequest(String name,
Data key,
InMemoryFormat inMemoryFormat) |
CacheReplaceRequest(String name,
Data key,
Data currentValue,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
InMemoryFormat inMemoryFormat) |
CacheReplaceRequest(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
InMemoryFormat inMemoryFormat) |
CacheSingleInvalidationMessage(String name,
Data key,
String sourceUuid) |
Constructor and Description |
---|
CacheClearRequest(String name,
Set<Data> keys,
boolean isRemoveAll,
int completionId) |
CacheGetAllRequest(String name,
Set<Data> keys,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
CacheLoadAllRequest(String name,
Set<Data> keys,
boolean replaceExistingValues) |
CachePutAllRequest(String name,
InMemoryFormat inMemoryFormat,
List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int partitionId) |
CachePutAllRequest(String name,
InMemoryFormat inMemoryFormat,
List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int partitionId) |
Modifier and Type | Method and Description |
---|---|
void |
CacheWanEventPublisher.publishWanReplicationRemove(String cacheName,
Data key)
This method will create a wrapper object using the given
CacheEntryView
and place it to wan replication queues. |
void |
CacheWanEventPublisher.publishWanReplicationRemoveBackup(String cacheName,
Data key)
Backup operations of operations that call
this#publishWanReplicationRemove(String, Data)
should call this method to provide wan event backups |
Modifier and Type | Method and Description |
---|---|
void |
CacheWanEventPublisher.publishWanReplicationUpdate(String cacheName,
CacheEntryView<Data,Data> entryView)
This method will create a wrapper object using the given
CacheEntryView
and place it to wan replication queues. |
void |
CacheWanEventPublisher.publishWanReplicationUpdate(String cacheName,
CacheEntryView<Data,Data> entryView)
This method will create a wrapper object using the given
CacheEntryView
and place it to wan replication queues. |
void |
CacheWanEventPublisher.publishWanReplicationUpdateBackup(String cacheName,
CacheEntryView<Data,Data> entryView)
Backup operations of operations that call
this#publishWanReplicationUpdate(String, CacheEntryView)
should call this method to provide wan event backups |
void |
CacheWanEventPublisher.publishWanReplicationUpdateBackup(String cacheName,
CacheEntryView<Data,Data> entryView)
Backup operations of operations that call
this#publishWanReplicationUpdate(String, CacheEntryView)
should call this method to provide wan event backups |
Modifier and Type | Method and Description |
---|---|
Data |
DefaultCacheEntryView.getKey() |
Data |
DefaultCacheEntryView.getValue() |
Constructor and Description |
---|
DefaultCacheEntryView(Data key,
Data value,
long expirationTime,
long lastAccessTime,
long accessHit) |
Constructor and Description |
---|
NearCacheDataRecord(Data value,
long creationTime,
long expiryTime) |
Modifier and Type | Method and Description |
---|---|
protected Data |
AbstractNearCacheRecordStore.toData(Object obj) |
protected Data |
AbstractNearCacheRecordStore.valueToData(V value) |
Modifier and Type | Method and Description |
---|---|
protected V |
AbstractNearCacheRecordStore.dataToValue(Data data) |
Modifier and Type | Field and Description |
---|---|
protected Map<String,Map<Data,CacheRecord>> |
CacheReplicationOperation.data |
Constructor and Description |
---|
AbstractMutatingCacheOperation(String name,
Data key,
int completionId) |
CacheBackupEntryProcessorOperation(String name,
Data key,
javax.cache.processor.EntryProcessor entryProcessor,
Object... arguments) |
CacheContainsKeyOperation(String name,
Data key) |
CacheEntryProcessorOperation(String name,
Data key,
int completionId,
javax.cache.processor.EntryProcessor entryProcessor,
Object... arguments) |
CacheGetAndRemoveOperation(String name,
Data key,
int completionId) |
CacheGetAndReplaceOperation(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int completionId) |
CacheGetOperation(String name,
Data key,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
CacheMergeOperation(String name,
Data key,
CacheEntryView<Data,Data> entryView,
CacheMergePolicy policy) |
CachePutBackupOperation(String name,
Data key,
CacheRecord cacheRecord) |
CachePutBackupOperation(String name,
Data key,
CacheRecord cacheRecord,
boolean wanOriginated) |
CachePutIfAbsentOperation(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int completionId) |
CachePutOperation(String name,
Data key,
Data value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
boolean get,
int completionId) |
CacheRemoveBackupOperation(String name,
Data key) |
CacheRemoveBackupOperation(String name,
Data key,
boolean wanOriginated) |
CacheRemoveOperation(String name,
Data key,
Data oldValue,
int completionId) |
CacheReplaceOperation(String name,
Data key,
Data oldValue,
Data newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int completionId) |
Constructor and Description |
---|
CacheGetAllOperation(String name,
Set<Data> keys,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
CacheGetAllOperationFactory(String name,
Set<Data> keys,
javax.cache.expiry.ExpiryPolicy expiryPolicy) |
CacheLoadAllOperation(String name,
Set<Data> keys,
boolean replaceExistingValues) |
CacheLoadAllOperationFactory(String name,
Set<Data> keys,
boolean replaceExistingValues) |
CacheMergeOperation(String name,
Data key,
CacheEntryView<Data,Data> entryView,
CacheMergePolicy policy) |
CacheMergeOperation(String name,
Data key,
CacheEntryView<Data,Data> entryView,
CacheMergePolicy policy) |
CachePutAllBackupOperation(String name,
Map<Data,CacheRecord> cacheRecords) |
CachePutAllOperation(String name,
List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int completionId) |
CachePutAllOperation(String name,
List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
int completionId) |
CacheRemoveAllBackupOperation(String name,
Set<Data> keys) |
CacheRemoveAllOperation(String name,
Set<Data> keys,
int completionId) |
CacheRemoveAllOperationFactory(String name,
Set<Data> keys,
int completionId) |
Modifier and Type | Interface and Description |
---|---|
interface |
CacheRecordMap<K extends Data,V extends CacheRecord> |
interface |
SampleableCacheRecordMap<K extends Data,V extends CacheRecord> |
Modifier and Type | Method and Description |
---|---|
<C extends EvictionCandidate<Data,CacheRecord>> |
CacheRecordHashMap.evict(Iterable<C> evictionCandidates,
EvictionListener<Data,CacheRecord> evictionListener) |
Modifier and Type | Method and Description |
---|---|
Data |
CacheDataRecord.getValue() |
Modifier and Type | Method and Description |
---|---|
protected CacheRecord |
CacheRecordFactory.createCacheDataRecord(Data dataValue,
long creationTime,
long expiryTime) |
protected CacheRecordHashMap.EvictableSamplingEntry |
CacheRecordHashMap.createSamplingEntry(Data key,
CacheRecord value) |
CacheRecord |
CacheRecordHashMap.put(Data key,
CacheRecord value) |
CacheRecord |
CacheRecordHashMap.putIfAbsent(Data key,
CacheRecord value) |
void |
CacheDataRecord.setValue(Data value) |
Modifier and Type | Method and Description |
---|---|
<C extends EvictionCandidate<Data,CacheRecord>> |
CacheRecordHashMap.evict(Iterable<C> evictionCandidates,
EvictionListener<Data,CacheRecord> evictionListener) |
Constructor and Description |
---|
CacheDataRecord(Data value,
long creationTime,
long expiryTime) |
CacheRecordHashMap.EvictableSamplingEntry(Data key,
CacheRecord value) |
Modifier and Type | Method and Description |
---|---|
protected Data |
ClientClusterWideIterator.toData(Object obj) |
Modifier and Type | Method and Description |
---|---|
protected void |
ClientCacheProxy.onLoadAll(Set<Data> keys,
Object response,
long start,
long end) |
Modifier and Type | Method and Description |
---|---|
Data |
ClientResponse.getResponse() |
Constructor and Description |
---|
ClientResponse(Data response,
long callId,
boolean isError) |
Modifier and Type | Method and Description |
---|---|
static SimpleEntryView<Data,Data> |
EntryViewCodec.decode(ClientMessage clientMessage) |
static SimpleEntryView<Data,Data> |
EntryViewCodec.decode(ClientMessage clientMessage) |
Modifier and Type | Method and Description |
---|---|
static int |
EntryViewCodec.calculateDataSize(SimpleEntryView<Data,Data> entryView) |
static int |
EntryViewCodec.calculateDataSize(SimpleEntryView<Data,Data> entryView) |
static void |
EntryViewCodec.encode(SimpleEntryView<Data,Data> dataEntryView,
ClientMessage clientMessage) |
static void |
EntryViewCodec.encode(SimpleEntryView<Data,Data> dataEntryView,
ClientMessage clientMessage) |
Modifier and Type | Method and Description |
---|---|
protected ClientMessage |
MapAddEntryListenerToKeyWithPredicateMessageTask.encodeEvent(Data keyData,
Data newValueData,
Data oldValueData,
Data meringValueData,
int type,
String uuid,
int numberOfAffectedEntries) |
protected abstract ClientMessage |
AbstractMapAddEntryListenerMessageTask.encodeEvent(Data keyData,
Data newValueData,
Data oldValueData,
Data meringValueData,
int type,
String uuid,
int numberOfEntriesAffected) |
protected ClientMessage |
MapAddNearCacheEntryListenerMessageTask.encodeEvent(Data keyData,
Data newValueData,
Data oldValueData,
Data meringValueData,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
MapAddEntryListenerToKeyMessageTask.encodeEvent(Data keyData,
Data newValueData,
Data oldValueData,
Data meringValueData,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
MapAddEntryListenerMessageTask.encodeEvent(Data keyData,
Data newValueData,
Data oldValueData,
Data meringValueData,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
MapAddEntryListenerWithPredicateMessageTask.encodeEvent(Data keyData,
Data newValueData,
Data oldValueData,
Data meringValueData,
int type,
String uuid,
int numberOfAffectedEntries) |
Modifier and Type | Method and Description |
---|---|
Data |
AbstractMultiMapAddEntryListenerMessageTask.getKey() |
Modifier and Type | Method and Description |
---|---|
protected ClientMessage |
MultiMapAddEntryListenerToKeyMessageTask.encodeEvent(Data key,
Data value,
Data oldValue,
int type,
String uuid,
int numberOfEntriesAffected) |
protected ClientMessage |
MultiMapAddEntryListenerMessageTask.encodeEvent(Data key,
Data value,
Data oldValue,
int type,
String uuid,
int numberOfEntriesAffected) |
protected abstract ClientMessage |
AbstractMultiMapAddEntryListenerMessageTask.encodeEvent(Data key,
Data value,
Data oldValue,
int type,
String uuid,
int numberOfEntriesAffected) |
Modifier and Type | Method and Description |
---|---|
Data |
ReplicatedMapAddNearCacheListenerMessageTask.getKey() |
Data |
ReplicatedMapAddEntryListenerMessageTask.getKey() |
Data |
ReplicatedMapAddEntryListenerToKeyMessageTask.getKey() |
abstract Data |
AbstractReplicatedMapAddEntryListenerMessageTask.getKey() |
Data |
ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask.getKey() |
Data |
ReplicatedMapAddEntryListenerWithPredicateMessageTask.getKey() |
Modifier and Type | Method and Description |
---|---|
protected ClientMessage |
ReplicatedMapAddNearCacheListenerMessageTask.encodeEvent(Data key,
Data newValue,
Data oldValue,
Data mergingValue,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
ReplicatedMapAddEntryListenerMessageTask.encodeEvent(Data key,
Data newValue,
Data oldValue,
Data mergingValue,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
ReplicatedMapAddEntryListenerToKeyMessageTask.encodeEvent(Data key,
Data newValue,
Data oldValue,
Data mergingValue,
int type,
String uuid,
int numberOfAffectedEntries) |
protected abstract ClientMessage |
AbstractReplicatedMapAddEntryListenerMessageTask.encodeEvent(Data key,
Data newValue,
Data oldValue,
Data mergingValue,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask.encodeEvent(Data key,
Data newValue,
Data oldValue,
Data mergingValue,
int type,
String uuid,
int numberOfAffectedEntries) |
protected ClientMessage |
ReplicatedMapAddEntryListenerWithPredicateMessageTask.encodeEvent(Data key,
Data newValue,
Data oldValue,
Data mergingValue,
int type,
String uuid,
int numberOfAffectedEntries) |
Modifier and Type | Method and Description |
---|---|
Object |
ListCodecTemplate.add(String name,
Data value)
Appends the specified element to the end of this list (optional operation).
|
Object |
SetCodecTemplate.add(String name,
Data value)
Adds the specified element to this set if it is not already present (optional operation).
|
Object |
RingbufferCodecTemplate.add(String name,
int overflowPolicy,
Data value)
Adds an item to the tail of the Ringbuffer.
|
Object |
TransactionalSetCodecTemplate.add(String name,
String txnId,
long threadId,
Data item)
Add new item to transactional set.
|
Object |
TransactionalListCodecTemplate.add(String name,
String txnId,
long threadId,
Data item)
Adds a new item to the transactional list.
|
Object |
ReplicatedMapCodecTemplate.addEntryListenerToKey(String name,
Data key,
boolean localOnly)
Adds the specified entry listener for the specified key.
|
Object |
MultiMapCodecTemplate.addEntryListenerToKey(String name,
Data key,
boolean includeValue,
boolean localOnly)
Adds the specified entry listener for the specified key.The listener will be notified for all
add/remove/update/evict events for the specified key only.
|
Object |
MapCodecTemplate.addEntryListenerToKey(String name,
Data key,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds a MapListener for this map.
|
Object |
ReplicatedMapCodecTemplate.addEntryListenerToKeyWithPredicate(String name,
Data key,
Data predicate,
boolean localOnly)
Adds an continuous entry listener for this map.
|
Object |
MapCodecTemplate.addEntryListenerToKeyWithPredicate(String name,
Data key,
Data predicate,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds a MapListener for this map.
|
Object |
ReplicatedMapCodecTemplate.addEntryListenerWithPredicate(String name,
Data predicate,
boolean localOnly)
Adds an continuous entry listener for this map.
|
Object |
MapCodecTemplate.addEntryListenerWithPredicate(String name,
Data predicate,
boolean includeValue,
int listenerFlags,
boolean localOnly)
Adds an continuous entry listener for this map.
|
Object |
MapCodecTemplate.addInterceptor(String name,
Data interceptor)
Adds an interceptor for this map.
|
void |
ListCodecTemplate.addWithIndex(String name,
int index,
Data value)
Inserts the specified element at the specified position in this list (optional operation).
|
void |
AtomicReferenceCodecTemplate.alter(String name,
Data function)
Alters the currently stored reference by applying a function on it.
|
void |
AtomicLongCodecTemplate.alter(String name,
Data function)
Alters the currently stored value by applying a function on it.
|
Object |
AtomicReferenceCodecTemplate.alterAndGet(String name,
Data function)
Alters the currently stored reference by applying a function on it and gets the result.
|
Object |
AtomicLongCodecTemplate.alterAndGet(String name,
Data function)
Alters the currently stored value by applying a function on it and gets the result.
|
Object |
AtomicReferenceCodecTemplate.apply(String name,
Data function)
Applies a function on the value, the actual stored value will not change.
|
Object |
AtomicLongCodecTemplate.apply(String name,
Data function)
Applies a function on the value, the actual stored value will not change.
|
Object |
ClientMessageTemplate.authenticationCustom(Data credentials,
String uuid,
String ownerUuid,
boolean isOwnerConnection,
String clientType,
byte serializationVersion) |
void |
EventResponseTemplate.CacheInvalidation(String name,
Data key,
String sourceUuid) |
Object |
AtomicReferenceCodecTemplate.compareAndSet(String name,
Data expected,
Data updated)
Atomically sets the value to the given updated value only if the current value the expected value.
|
Object |
AtomicReferenceCodecTemplate.contains(String name,
Data expected)
Checks if the reference contains the value.
|
Object |
ListCodecTemplate.contains(String name,
Data value)
Returns true if this list contains the specified element.
|
Object |
QueueCodecTemplate.contains(String name,
Data value)
Returns true if this queue contains the specified element.
|
Object |
SetCodecTemplate.contains(String name,
Data value)
Returns true if this set contains the specified element.
|
Object |
MultiMapCodecTemplate.containsEntry(String name,
Data key,
Data value,
long threadId)
Returns whether the multimap contains the given key-value pair.
|
Object |
ReplicatedMapCodecTemplate.containsKey(String name,
Data key)
Returns true if this map contains a mapping for the specified key.
|
Object |
CacheCodecTemplate.containsKey(String name,
Data key)
Determines if the Cache contains an entry for the specified key.
|
Object |
MultiMapCodecTemplate.containsKey(String name,
Data key,
long threadId)
Returns whether the multimap contains an entry with the key.
|
Object |
MapCodecTemplate.containsKey(String name,
Data key,
long threadId)
Returns true if this map contains a mapping for the specified key.
|
Object |
TransactionalMapCodecTemplate.containsKey(String name,
String txnId,
long threadId,
Data key)
Returns true if this map contains an entry for the specified key.
|
Object |
ReplicatedMapCodecTemplate.containsValue(String name,
Data value)
Returns true if this map maps one or more keys to the specified value.
|
Object |
MultiMapCodecTemplate.containsValue(String name,
Data value)
Returns whether the multimap contains an entry with the value.
|
Object |
MapCodecTemplate.containsValue(String name,
Data value)
Returns true if this map maps one or more keys to the specified value.This operation will probably require time
linear in the map size for most implementations of the Map interface.
|
Object |
CacheCodecTemplate.createConfig(Data cacheConfig,
boolean createAlsoOnOthers) |
void |
ResponseTemplate.Data(Data response) |
void |
MapCodecTemplate.delete(String name,
Data key,
long threadId)
Removes the mapping for a key from this map if it is present.Unlike remove(Object), this operation does not return
the removed value, which avoids the serialization cost of the returned value.If the removed value will not be used,
a delete operation is preferred over a remove operation for better performance.
|
void |
TransactionalMapCodecTemplate.delete(String name,
String txnId,
long threadId,
Data key)
Removes the mapping for a key from this map if it is present.
|
Object |
MapCodecTemplate.entriesWithPagingPredicate(String name,
Data predicate) |
Object |
MapCodecTemplate.entriesWithPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the matching entries.Specified predicate
runs on all members in parallel.
|
void |
EventResponseTemplate.Entry(Data key,
Data value,
Data oldValue,
Data mergingValue,
int eventType,
String uuid,
int numberOfAffectedEntries) |
Object |
CacheCodecTemplate.entryProcessor(String name,
Data key,
Data entryProcessor,
List<Data> arguments,
int completionId) |
Object |
MapCodecTemplate.evict(String name,
Data key,
long threadId)
Evicts the specified key from this map.
|
Object |
MapCodecTemplate.executeOnAllKeys(String name,
Data entryProcessor)
Applies the user defined EntryProcessor to the all entries in the map.Returns the results mapped by each key in the map.
|
Object |
MapCodecTemplate.executeOnKey(String name,
Data entryProcessor,
Data key,
long threadId)
Applies the user defined EntryProcessor to the entry mapped by the key.
|
Object |
MapCodecTemplate.executeOnKeys(String name,
Data entryProcessor,
List<Data> keys)
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.The results mapped by
each key in the collection.
|
Object |
MapCodecTemplate.executeWithPredicate(String name,
Data entryProcessor,
Data predicate)
Applies the user defined EntryProcessor to the entries in the map which satisfies provided predicate.
|
void |
MultiMapCodecTemplate.forceUnlock(String name,
Data key)
Releases the lock for the specified key regardless of the lock owner.
|
void |
MapCodecTemplate.forceUnlock(String name,
Data key)
Releases the lock for the specified key regardless of the lock owner.It always successfully unlocks the key,
never blocks,and returns immediately.
|
Object |
MapReduceCodecTemplate.forCustom(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
Data keyValueSource,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forList(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String listName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forMap(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String mapName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forMultiMap(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String multiMapName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forSet(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String setName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
ReplicatedMapCodecTemplate.get(String name,
Data key)
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
|
Object |
CacheCodecTemplate.get(String name,
Data key,
Data expiryPolicy)
Retrieves the mapped value of the given key using a custom javax.cache.expiry.ExpiryPolicy.
|
Object |
MultiMapCodecTemplate.get(String name,
Data key,
long threadId)
Returns the collection of values associated with the key.
|
Object |
MapCodecTemplate.get(String name,
Data key,
long threadId)
This method returns a clone of the original value, so modifying the returned value does not change the actual
value in the map.
|
Object |
TransactionalMapCodecTemplate.get(String name,
String txnId,
long threadId,
Data key)
Returns the value for the specified key, or null if this map does not contain this key.
|
Object |
TransactionalMultiMapCodecTemplate.get(String name,
String txnId,
long threadId,
Data key)
Returns the collection of values associated with the key.
|
Object |
CacheCodecTemplate.getAll(String name,
List<Data> keys,
Data expiryPolicy)
Gets a collection of entries from the cache with custom expiry policy, returning them as Map of the values
associated with the set of keys requested.
|
Object |
AtomicReferenceCodecTemplate.getAndAlter(String name,
Data function)
Alters the currently stored reference by applying a function on it on and gets the old value.
|
Object |
AtomicLongCodecTemplate.getAndAlter(String name,
Data function)
Alters the currently stored value by applying a function on it on and gets the old value.
|
Object |
CacheCodecTemplate.getAndRemove(String name,
Data key,
int completionId)
Atomically removes the entry for a key only if currently mapped to some value.
|
Object |
CacheCodecTemplate.getAndReplace(String name,
Data key,
Data value,
Data expiryPolicy,
int completionId)
Atomically replaces the assigned value of the given key by the specified value using a custom
javax.cache.expiry.ExpiryPolicy and returns the previously assigned value.
|
Object |
AtomicReferenceCodecTemplate.getAndSet(String name,
Data newValue)
Gets the old value and sets the new value.
|
Object |
MapCodecTemplate.getEntryView(String name,
Data key,
long threadId)
Returns the EntryView for the specified key.
|
Object |
TransactionalMapCodecTemplate.getForUpdate(String name,
String txnId,
long threadId,
Data key)
Locks the key and then gets and returns the value to which the specified key is mapped.
|
void |
EventResponseTemplate.IMapInvalidation(Data key) |
Object |
ListCodecTemplate.indexOf(String name,
Data value)
Returns the index of the first occurrence of the specified element in this list, or -1 if this list does not
contain the element.
|
Object |
MultiMapCodecTemplate.isLocked(String name,
Data key)
Checks the lock for the specified key.
|
Object |
MapCodecTemplate.isLocked(String name,
Data key)
Checks the lock for the specified key.If the lock is acquired then returns true, else returns false.
|
void |
EventResponseTemplate.Item(Data item,
String uuid,
int eventType) |
Object |
MapCodecTemplate.keySetWithPagingPredicate(String name,
Data predicate) |
Object |
MapCodecTemplate.keySetWithPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the keys of matching entries.
|
Object |
TransactionalMapCodecTemplate.keySetWithPredicate(String name,
String txnId,
long threadId,
Data predicate)
Queries the map based on the specified predicate and returns the keys of matching entries.
|
Object |
ListCodecTemplate.lastIndexOf(String name,
Data value)
Returns the index of the last occurrence of the specified element in this list, or -1 if this list does not
contain the element.
|
void |
CacheCodecTemplate.listenerRegistration(String name,
Data listenerConfig,
boolean shouldRegister,
Address address) |
void |
MultiMapCodecTemplate.lock(String name,
Data key,
long threadId,
long ttl)
Acquires the lock for the specified key for the specified lease time.
|
void |
MapCodecTemplate.lock(String name,
Data key,
long threadId,
long ttl)
Acquires the lock for the specified lease time.After lease time, lock will be released.If the lock is not
available then the current thread becomes disabled for thread scheduling purposes and lies dormant until the lock
has been acquired.
|
Object |
QueueCodecTemplate.offer(String name,
Data value,
long timeoutMillis)
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to
become available.
|
Object |
TransactionalQueueCodecTemplate.offer(String name,
String txnId,
long threadId,
Data item,
long timeout)
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to
become available.
|
void |
TopicCodecTemplate.publish(String name,
Data message)
Publishes the message to all subscribers of this topic
|
Object |
EnterpriseMapCodecTemplate.publisherCreate(String mapName,
String cacheName,
Data predicate,
int batchSize,
int bufferSize,
long delaySeconds,
boolean populate,
boolean coalesce) |
Object |
EnterpriseMapCodecTemplate.publisherCreateWithValue(String mapName,
String cacheName,
Data predicate,
int batchSize,
int bufferSize,
long delaySeconds,
boolean populate,
boolean coalesce) |
void |
QueueCodecTemplate.put(String name,
Data value)
Inserts the specified element into this queue, waiting if necessary for space to become available.
|
Object |
CacheCodecTemplate.put(String name,
Data key,
Data value,
Data expiryPolicy,
boolean get,
int completionId) |
Object |
ReplicatedMapCodecTemplate.put(String name,
Data key,
Data value,
long ttl)
Associates a given value to the specified key and replicates it to the cluster.
|
Object |
MultiMapCodecTemplate.put(String name,
Data key,
Data value,
long threadId)
Stores a key-value pair in the multimap.
|
Object |
MapCodecTemplate.put(String name,
Data key,
Data value,
long threadId,
long ttl)
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl
If ttl is 0, then the entry lives forever.This method returns a clone of the previous value, not the original
(identically equal) value previously put into the map.Time resolution for TTL is seconds.
|
Object |
TransactionalMultiMapCodecTemplate.put(String name,
String txnId,
long threadId,
Data key,
Data value)
Stores a key-value pair in the multimap.
|
Object |
TransactionalMapCodecTemplate.put(String name,
String txnId,
long threadId,
Data key,
Data value,
long ttl)
Associates the specified value with the specified key in this map.
|
void |
CacheCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries,
Data expiryPolicy,
int completionId) |
Object |
CacheCodecTemplate.putIfAbsent(String name,
Data key,
Data value,
Data expiryPolicy,
int completionId)
Associates the specified key with the given value if and only if there is not yet a mapping defined for the
specified key.
|
Object |
MapCodecTemplate.putIfAbsent(String name,
Data key,
Data value,
long threadId,
long ttl)
Puts an entry into this map with a given ttl (time to live) value if the specified key is not already associated
with a value.
|
Object |
TransactionalMapCodecTemplate.putIfAbsent(String name,
String txnId,
long threadId,
Data key,
Data value)
If the specified key is not already associated with a value, associate it with the given value.
|
void |
MapCodecTemplate.putTransient(String name,
Data key,
Data value,
long threadId,
long ttl)
Same as put except that MapStore, if defined, will not be called to store/persist the entry.
|
Object |
RingbufferCodecTemplate.readMany(String name,
long startSequence,
int minCount,
int maxCount,
Data filter)
Reads a batch of items from the Ringbuffer.
|
Object |
ReplicatedMapCodecTemplate.remove(String name,
Data key)
Removes the mapping for a key from this map if it is present (optional operation).
|
Object |
ListCodecTemplate.remove(String name,
Data value)
Removes the first occurrence of the specified element from this list, if it is present (optional operation).
|
Object |
QueueCodecTemplate.remove(String name,
Data value)
Retrieves and removes the head of this queue.
|
Object |
SetCodecTemplate.remove(String name,
Data value)
Removes the specified element from this set if it is present (optional operation).
|
Object |
CacheCodecTemplate.remove(String name,
Data key,
Data currentValue,
int completionId)
Atomically removes the mapping for a key only if currently mapped to the given value.
|
Object |
MultiMapCodecTemplate.remove(String name,
Data key,
long threadId)
Removes the given key value pair from the multimap.
|
Object |
MapCodecTemplate.remove(String name,
Data key,
long threadId)
Removes the mapping for a key from this map if it is present (optional operation).
|
Object |
TransactionalSetCodecTemplate.remove(String name,
String txnId,
long threadId,
Data item)
Remove item from transactional set.
|
Object |
TransactionalMapCodecTemplate.remove(String name,
String txnId,
long threadId,
Data key)
Removes the mapping for a key from this map if it is present.
|
Object |
TransactionalMultiMapCodecTemplate.remove(String name,
String txnId,
long threadId,
Data key)
Removes the given key value pair from the multimap.
|
Object |
TransactionalListCodecTemplate.remove(String name,
String txnId,
long threadId,
Data item)
Remove item from the transactional list
|
Object |
MultiMapCodecTemplate.removeEntry(String name,
Data key,
Data value,
long threadId)
Removes all the entries with the given key.
|
Object |
TransactionalMultiMapCodecTemplate.removeEntry(String name,
String txnId,
long threadId,
Data key,
Data value)
Removes all the entries associated with the given key.
|
Object |
MapCodecTemplate.removeIfSame(String name,
Data key,
Data value,
long threadId)
Removes the mapping for a key from this map if existing value equal to the this value
|
Object |
TransactionalMapCodecTemplate.removeIfSame(String name,
String txnId,
long threadId,
Data key,
Data value)
Removes the entry for a key only if currently mapped to a given value.
|
Object |
CacheCodecTemplate.replace(String name,
Data key,
Data oldValue,
Data newValue,
Data expiryPolicy,
int completionId)
Atomically replaces the currently assigned value for the given key with the specified newValue if and only if the
currently assigned value equals the value of oldValue using a custom javax.cache.expiry.ExpiryPolicy
If the cache is configured for write-through operation mode, the underlying configured
javax.cache.integration.CacheWriter might be called to store the value of the key to any kind of external resource.
|
Object |
MapCodecTemplate.replace(String name,
Data key,
Data value,
long threadId)
Replaces the entry for a key only if currently mapped to a given value.
|
Object |
TransactionalMapCodecTemplate.replace(String name,
String txnId,
long threadId,
Data key,
Data value)
Replaces the entry for a key only if it is currently mapped to some value.
|
Object |
MapCodecTemplate.replaceIfSame(String name,
Data key,
Data testValue,
Data value,
long threadId)
Replaces the the entry for a key only if existing values equal to the testValue
|
Object |
TransactionalMapCodecTemplate.replaceIfSame(String name,
String txnId,
long threadId,
Data key,
Data oldValue,
Data newValue)
Replaces the entry for a key only if currently mapped to a given value.
|
void |
AtomicReferenceCodecTemplate.set(String name,
Data newValue)
Atomically sets the given value.
|
void |
MapCodecTemplate.set(String name,
Data key,
Data value,
long threadId,
long ttl)
Puts an entry into this map with a given ttl (time to live) value.Entry will expire and get evicted after the ttl
If ttl is 0, then the entry lives forever.
|
Object |
ListCodecTemplate.set(String name,
int index,
Data value)
The element previously at the specified position
|
void |
TransactionalMapCodecTemplate.set(String name,
String txnId,
long threadId,
Data key,
Data value)
Associates the specified value with the specified key in this map.
|
Object |
AtomicReferenceCodecTemplate.setAndGet(String name,
Data newValue)
Sets and gets the value.
|
Object |
ExecutorServiceCodecTemplate.submitToAddress(String name,
String uuid,
Data callable,
Address address) |
Object |
MapCodecTemplate.submitToKey(String name,
Data entryProcessor,
Data key,
long threadId)
Applies the user defined EntryProcessor to the entry mapped by the key.
|
Object |
ExecutorServiceCodecTemplate.submitToPartition(String name,
String uuid,
Data callable,
int partitionId) |
void |
EventResponseTemplate.Topic(Data item,
long publishTime,
String uuid) |
Object |
MultiMapCodecTemplate.tryLock(String name,
Data key,
long threadId,
long lease,
long timeout)
Tries to acquire the lock for the specified key for the specified lease time.
|
Object |
MapCodecTemplate.tryLock(String name,
Data key,
long threadId,
long lease,
long timeout)
Tries to acquire the lock for the specified key for the specified lease time.After lease time, the lock will be
released.If the lock is not available, then the current thread becomes disabled for thread scheduling
purposes and lies dormant until one of two things happens the lock is acquired by the current thread, or
the specified waiting time elapses.
|
Object |
MapCodecTemplate.tryPut(String name,
Data key,
Data value,
long threadId,
long timeout)
Tries to put the given key and value into this map within a specified timeout value.
|
Object |
MapCodecTemplate.tryRemove(String name,
Data key,
long threadId,
long timeout)
Tries to remove the entry with the given key from this map within the specified timeout value.
|
void |
MultiMapCodecTemplate.unlock(String name,
Data key,
long threadId)
Releases the lock for the specified key regardless of the lock owner.
|
void |
MapCodecTemplate.unlock(String name,
Data key,
long threadId)
Releases the lock for the specified key.
|
Object |
MultiMapCodecTemplate.valueCount(String name,
Data key,
long threadId)
Returns the number of values that match the given key in the multimap.
|
Object |
TransactionalMultiMapCodecTemplate.valueCount(String name,
String txnId,
long threadId,
Data key)
Returns the number of values matching the given key in the multimap.
|
Object |
MapCodecTemplate.valuesWithPagingPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the values of matching entries.
|
Object |
MapCodecTemplate.valuesWithPredicate(String name,
Data predicate)
Queries the map based on the specified predicate and returns the values of matching entries.Specified predicate
runs on all members in parallel.
|
Object |
TransactionalMapCodecTemplate.valuesWithPredicate(String name,
String txnId,
long threadId,
Data predicate)
Queries the map based on the specified predicate and returns the values of matching entries.Specified predicate
runs on all members in parallel.
|
Modifier and Type | Method and Description |
---|---|
Object |
ListCodecTemplate.addAll(String name,
List<Data> valueList)
Appends all of the elements in the specified collection to the end of this list, in the order that they are
returned by the specified collection's iterator (optional operation).
|
Object |
QueueCodecTemplate.addAll(String name,
List<Data> dataList)
Adds all of the elements in the specified collection to this collection (optional operation).The behavior of this
operation is undefined if the specified collection is modified while the operation is in progress.
|
Object |
SetCodecTemplate.addAll(String name,
List<Data> valueList)
Adds all of the elements in the specified collection to this set if they're not already present
(optional operation).
|
Object |
RingbufferCodecTemplate.addAll(String name,
List<Data> valueList,
int overflowPolicy)
Adds all the items of a collection to the tail of the Ringbuffer.
|
Object |
ListCodecTemplate.addAllWithIndex(String name,
int index,
List<Data> valueList)
Inserts all of the elements in the specified collection into this list at the specified position (optional operation).
|
void |
EventResponseTemplate.CacheBatchInvalidation(String name,
List<Data> keys,
List<String> sourceUuids) |
void |
ResponseTemplate.CacheKeyIteratorResult(int tableIndex,
List<Data> keys) |
Object |
ListCodecTemplate.compareAndRemoveAll(String name,
List<Data> values)
Removes from this list all of its elements that are contained in the specified collection (optional operation).
|
Object |
QueueCodecTemplate.compareAndRemoveAll(String name,
List<Data> dataList)
Removes all of this collection's elements that are also contained in the specified collection (optional operation).
|
Object |
SetCodecTemplate.compareAndRemoveAll(String name,
List<Data> values)
Removes from this set all of its elements that are contained in the specified collection (optional operation).
|
Object |
ListCodecTemplate.compareAndRetainAll(String name,
List<Data> values)
Retains only the elements in this list that are contained in the specified collection (optional operation).
|
Object |
QueueCodecTemplate.compareAndRetainAll(String name,
List<Data> dataList)
Retains only the elements in this collection that are contained in the specified collection (optional operation).
|
Object |
SetCodecTemplate.compareAndRetainAll(String name,
List<Data> values)
Retains only the elements in this set that are contained in the specified collection (optional operation).
|
Object |
ListCodecTemplate.containsAll(String name,
List<Data> values)
Returns true if this list contains all of the elements of the specified collection.
|
Object |
QueueCodecTemplate.containsAll(String name,
List<Data> dataList)
Return true if this collection contains all of the elements in the specified collection.
|
Object |
SetCodecTemplate.containsAll(String name,
List<Data> items)
Returns true if this set contains all of the elements of the specified collection.
|
Object |
CacheCodecTemplate.entryProcessor(String name,
Data key,
Data entryProcessor,
List<Data> arguments,
int completionId) |
void |
ResponseTemplate.EntryView(SimpleEntryView<Data,Data> response) |
void |
ResponseTemplate.EntryView(SimpleEntryView<Data,Data> response) |
Object |
MapCodecTemplate.executeOnKeys(String name,
Data entryProcessor,
List<Data> keys)
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.The results mapped by
each key in the collection.
|
Object |
MapReduceCodecTemplate.forCustom(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
Data keyValueSource,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forList(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String listName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forMap(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String mapName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forMultiMap(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String multiMapName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapReduceCodecTemplate.forSet(String name,
String jobId,
Data predicate,
Data mapper,
Data combinerFactory,
Data reducerFactory,
String setName,
int chunkSize,
List<Data> keys,
String topologyChangedStrategy) |
Object |
MapCodecTemplate.getAll(String name,
List<Data> keys)
Returns the entries for the given keys.
|
Object |
CacheCodecTemplate.getAll(String name,
List<Data> keys,
Data expiryPolicy)
Gets a collection of entries from the cache with custom expiry policy, returning them as Map of the values
associated with the set of keys requested.
|
void |
EventResponseTemplate.IMapBatchInvalidation(List<Data> keys) |
void |
ResponseTemplate.ListData(List<Data> response) |
void |
ResponseTemplate.ListEntry(List<Map.Entry<Data,Data>> response) |
void |
ResponseTemplate.ListEntry(List<Map.Entry<Data,Data>> response) |
void |
CacheCodecTemplate.loadAll(String name,
List<Data> keys,
boolean replaceExistingValues) |
void |
MapCodecTemplate.loadGivenKeys(String name,
List<Data> keys,
boolean replaceExistingValues)
Loads the given keys.
|
void |
ReplicatedMapCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries)
Copies all of the mappings from the specified map to this map (optional operation).
|
void |
ReplicatedMapCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries)
Copies all of the mappings from the specified map to this map (optional operation).
|
void |
CacheCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries,
Data expiryPolicy,
int completionId) |
void |
CacheCodecTemplate.putAll(String name,
List<Map.Entry<Data,Data>> entries,
Data expiryPolicy,
int completionId) |
void |
MapCodecTemplate.putAll(String name,
Map<Data,Data> entries)
Copies all of the mappings from the specified map to this map (optional operation).The effect of this call is
equivalent to that of calling put(Object,Object) put(k, v) on this map once for each mapping from key k to value
v in the specified map.The behavior of this operation is undefined if the specified map is modified while the
operation is in progress.
|
void |
MapCodecTemplate.putAll(String name,
Map<Data,Data> entries)
Copies all of the mappings from the specified map to this map (optional operation).The effect of this call is
equivalent to that of calling put(Object,Object) put(k, v) on this map once for each mapping from key k to value
v in the specified map.The behavior of this operation is undefined if the specified map is modified while the
operation is in progress.
|
void |
ResponseTemplate.ReadResultSet(int readCount,
List<Data> items) |
void |
CacheCodecTemplate.removeAllKeys(String name,
List<Data> keys,
int completionId)
Removes entries for the specified keys.
|
Modifier and Type | Method and Description |
---|---|
Data |
MessageFlyweight.getData() |
Modifier and Type | Method and Description |
---|---|
List<Data> |
MessageFlyweight.getDataList() |
Set<Data> |
MessageFlyweight.getDataSet() |
Map.Entry<Data,Data> |
MessageFlyweight.getMapEntry() |
Map.Entry<Data,Data> |
MessageFlyweight.getMapEntry() |
Modifier and Type | Method and Description |
---|---|
static int |
ParameterUtil.calculateDataSize(Data data) |
MessageFlyweight |
MessageFlyweight.set(Data data) |
Modifier and Type | Method and Description |
---|---|
static int |
ParameterUtil.calculateDataSize(Map.Entry<Data,Data> entry) |
static int |
ParameterUtil.calculateDataSize(Map.Entry<Data,Data> entry) |
MessageFlyweight |
MessageFlyweight.set(Collection<Data> value) |
MessageFlyweight |
MessageFlyweight.set(Map.Entry<Data,Data> entry) |
MessageFlyweight |
MessageFlyweight.set(Map.Entry<Data,Data> entry) |
Modifier and Type | Field and Description |
---|---|
protected NearCache<Data,Object> |
NearCachedClientMapProxy.nearCache |
Modifier and Type | Method and Description |
---|---|
NearCache<Data,Object> |
NearCachedClientMapProxy.getNearCache() |
Modifier and Type | Method and Description |
---|---|
protected boolean |
NearCachedClientMapProxy.containsKeyInternal(Data keyData) |
protected boolean |
ClientMapProxy.containsKeyInternal(Data keyData) |
protected void |
NearCachedClientMapProxy.deleteInternal(Data keyData) |
protected void |
ClientMapProxy.deleteInternal(Data keyData) |
protected boolean |
NearCachedClientMapProxy.evictInternal(Data keyData) |
protected boolean |
ClientMapProxy.evictInternal(Data keyData) |
Object |
NearCachedClientMapProxy.executeOnKeyInternal(Data keyData,
EntryProcessor entryProcessor) |
Object |
ClientMapProxy.executeOnKeyInternal(Data keyData,
EntryProcessor entryProcessor) |
ICompletableFuture<V> |
NearCachedClientMapProxy.getAsyncInternal(Data keyData) |
protected ICompletableFuture<V> |
ClientMapProxy.getAsyncInternal(Data keyData) |
protected V |
NearCachedClientMapProxy.getInternal(Data keyData) |
protected V |
ClientMapProxy.getInternal(Data keyData) |
void |
NearCachedClientMapProxy.ClientMapAddNearCacheEventHandler.handle(Data key) |
protected void |
NearCachedClientMapProxy.invalidateNearCache(Data key) |
protected Future<V> |
NearCachedClientMapProxy.putAsyncInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected Future<V> |
ClientMapProxy.putAsyncInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected V |
NearCachedClientMapProxy.putIfAbsentInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected V |
ClientMapProxy.putIfAbsentInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected V |
NearCachedClientMapProxy.putInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected V |
ClientMapProxy.putInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected void |
NearCachedClientMapProxy.putTransientInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected void |
ClientMapProxy.putTransientInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected Future<V> |
NearCachedClientMapProxy.removeAsyncInternal(Data keyData) |
protected Future<V> |
ClientMapProxy.removeAsyncInternal(Data keyData) |
protected com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.ResponseParameters |
NearCachedClientMapProxy.removeInternal(Data keyData) |
protected com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.ResponseParameters |
ClientMapProxy.removeInternal(Data keyData) |
protected boolean |
NearCachedClientMapProxy.removeInternal(Data keyData,
Data valueData) |
protected boolean |
ClientMapProxy.removeInternal(Data keyData,
Data valueData) |
protected boolean |
NearCachedClientMapProxy.replaceIfSameInternal(Data keyData,
Data oldValueData,
Data newValueData) |
protected boolean |
ClientMapProxy.replaceIfSameInternal(Data keyData,
Data oldValueData,
Data newValueData) |
protected V |
NearCachedClientMapProxy.replaceInternal(Data keyData,
Data valueData) |
protected V |
ClientMapProxy.replaceInternal(Data keyData,
Data valueData) |
protected void |
NearCachedClientMapProxy.setInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected void |
ClientMapProxy.setInternal(long ttl,
TimeUnit timeunit,
Data keyData,
Data valueData) |
Future |
NearCachedClientMapProxy.submitToKeyInternal(Data keyData,
EntryProcessor entryProcessor) |
Future |
ClientMapProxy.submitToKeyInternal(Data keyData,
EntryProcessor entryProcessor) |
void |
NearCachedClientMapProxy.submitToKeyInternal(Data keyData,
EntryProcessor entryProcessor,
ExecutionCallback callback) |
void |
ClientMapProxy.submitToKeyInternal(Data keyData,
EntryProcessor entryProcessor,
ExecutionCallback callback) |
protected boolean |
NearCachedClientMapProxy.tryPutInternal(long timeout,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected boolean |
ClientMapProxy.tryPutInternal(long timeout,
TimeUnit timeunit,
Data keyData,
Data valueData) |
protected boolean |
NearCachedClientMapProxy.tryRemoveInternal(long timeout,
TimeUnit timeunit,
Data keyData) |
protected boolean |
ClientMapProxy.tryRemoveInternal(long timeout,
TimeUnit timeunit,
Data keyData) |
Modifier and Type | Method and Description |
---|---|
protected List<com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.ResponseParameters> |
NearCachedClientMapProxy.getAllInternal(Map<Integer,List<Data>> pIdToKeyData,
Map<K,V> result) |
protected List<com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.ResponseParameters> |
ClientMapProxy.getAllInternal(Map<Integer,List<Data>> partitionToKeyData,
Map<K,V> result) |
void |
NearCachedClientMapProxy.ClientMapAddNearCacheEventHandler.handle(Collection<Data> keys) |
protected void |
NearCachedClientMapProxy.invalidateNearCache(Collection<Data> keys) |
protected void |
NearCachedClientMapProxy.loadAllInternal(boolean replaceExistingValues,
Set<Data> dataKeys) |
protected void |
ClientMapProxy.loadAllInternal(boolean replaceExistingValues,
Set<Data> dataKeys) |
protected Map<K,Object> |
NearCachedClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entrySet) |
protected Map<K,Object> |
NearCachedClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entrySet) |
protected Map<K,Object> |
ClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entries) |
protected Map<K,Object> |
ClientMapProxy.prepareResult(Collection<Map.Entry<Data,Data>> entries) |
protected void |
NearCachedClientMapProxy.putAllInternal(Map<Integer,Map<Data,Data>> entryMap) |
protected void |
NearCachedClientMapProxy.putAllInternal(Map<Integer,Map<Data,Data>> entryMap) |
protected void |
ClientMapProxy.putAllInternal(Map<Integer,Map<Data,Data>> entryMap) |
protected void |
ClientMapProxy.putAllInternal(Map<Integer,Map<Data,Data>> entryMap) |
Modifier and Type | Method and Description |
---|---|
protected Data |
ClientProxy.toData(Object o) |
Modifier and Type | Method and Description |
---|---|
int |
ClientPartitionService.getPartitionId(Data key) |
Modifier and Type | Method and Description |
---|---|
int |
ClientPartitionServiceImpl.getPartitionId(Data key) |
Modifier and Type | Method and Description |
---|---|
Data |
DataAwareItemEvent.getItemData() |
Constructor and Description |
---|
DataAwareItemEvent(String name,
ItemEventType itemEventType,
Data dataItem,
Member member,
SerializationService serializationService) |
Modifier and Type | Field and Description |
---|---|
protected Data |
CollectionItem.value |
Modifier and Type | Method and Description |
---|---|
Data |
CollectionEvent.getData() |
Data |
CollectionItem.getValue() |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
CollectionContainer.addAll(List<Data> valueList) |
Map<Long,Data> |
CollectionContainer.clear() |
Map<Long,Data> |
CollectionContainer.compareAndRemove(boolean retain,
Set<Data> valueSet) |
List<Data> |
CollectionContainer.getAll() |
Modifier and Type | Method and Description |
---|---|
long |
CollectionContainer.add(Data value) |
void |
CollectionContainer.addBackup(long itemId,
Data value) |
void |
CollectionContainer.commitAdd(long itemId,
Data value) |
void |
CollectionContainer.commitAddBackup(long itemId,
Data value) |
CollectionItem |
CollectionContainer.remove(Data value) |
Long |
CollectionContainer.reserveAdd(String transactionId,
Data value) |
CollectionItem |
CollectionContainer.reserveRemove(long reservedItemId,
Data value,
String transactionId) |
void |
CollectionItem.setValue(Data value) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
CollectionContainer.addAll(List<Data> valueList) |
void |
CollectionContainer.addAllBackup(Map<Long,Data> valueMap) |
Map<Long,Data> |
CollectionContainer.compareAndRemove(boolean retain,
Set<Data> valueSet) |
boolean |
CollectionContainer.contains(Set<Data> valueSet) |
Constructor and Description |
---|
CollectionEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
CollectionItem(long itemId,
Data value) |
TxCollectionItem(long itemId,
Data value,
String transactionId,
boolean removeOperation) |
Modifier and Type | Field and Description |
---|---|
protected Data |
CollectionAddRequest.value |
Modifier and Type | Field and Description |
---|---|
protected List<Data> |
CollectionAddAllRequest.valueList |
Constructor and Description |
---|
CollectionAddRequest(String name,
Data value) |
CollectionContainsRequest(String name,
Data value) |
CollectionRemoveRequest(String name,
Data value) |
Constructor and Description |
---|
CollectionAddAllRequest(String name,
List<Data> valueList) |
CollectionCompareAndRemoveRequest(String name,
Set<Data> valueSet,
boolean retain) |
CollectionContainsRequest(String name,
Set<Data> valueSet) |
Modifier and Type | Field and Description |
---|---|
protected Data |
CollectionAddOperation.value |
Modifier and Type | Field and Description |
---|---|
protected List<Data> |
CollectionAddAllOperation.valueList |
protected Map<Long,Data> |
CollectionAddAllOperation.valueMap |
protected Map<Long,Data> |
CollectionAddAllBackupOperation.valueMap |
Modifier and Type | Method and Description |
---|---|
protected void |
CollectionOperation.publishEvent(ItemEventType eventType,
Data data) |
Constructor and Description |
---|
CollectionAddBackupOperation(String name,
long itemId,
Data value) |
CollectionAddOperation(String name,
Data value) |
CollectionRemoveOperation(String name,
Data value) |
Constructor and Description |
---|
CollectionAddAllBackupOperation(String name,
Map<Long,Data> valueMap) |
CollectionAddAllOperation(String name,
List<Data> valueList) |
CollectionCompareAndRemoveOperation(String name,
boolean retain,
Set<Data> valueSet) |
CollectionContainsOperation(String name,
Set<Data> valueSet) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
ListContainer.addAll(int index,
List<Data> valueList) |
List<Data> |
ListContainer.sub(int from,
int to) |
Modifier and Type | Method and Description |
---|---|
CollectionItem |
ListContainer.add(int index,
Data value) |
int |
ListContainer.indexOf(boolean last,
Data value) |
CollectionItem |
ListContainer.set(int index,
long itemId,
Data value) |
void |
ListContainer.setBackup(long oldItemId,
long itemId,
Data value) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
ListContainer.addAll(int index,
List<Data> valueList) |
Constructor and Description |
---|
ListAddRequest(String name,
Data value,
int index) |
ListIndexOfRequest(String name,
Data value,
boolean last) |
ListSetRequest(String name,
int index,
Data value) |
Constructor and Description |
---|
ListAddAllRequest(String name,
List<Data> valueList,
int index) |
Constructor and Description |
---|
ListAddOperation(String name,
int index,
Data value) |
ListIndexOfOperation(String name,
boolean last,
Data value) |
ListSetBackupOperation(String name,
long oldItemId,
long itemId,
Data value) |
ListSetOperation(String name,
int index,
Data value) |
Constructor and Description |
---|
ListAddAllOperation(String name,
int index,
List<Data> valueList) |
Modifier and Type | Field and Description |
---|---|
protected Data |
QueueItem.data |
Modifier and Type | Method and Description |
---|---|
Data |
QueueItem.getData() |
Data |
QueueContainer.getDataFromMap(long itemId) |
Data |
QueueStoreWrapper.load(Long key) |
Data |
QueueContainer.txnCommitPoll(long itemId) |
Data |
QueueContainer.txnCommitPollBackup(long itemId) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
QueueContainer.addAll(Collection<Data> dataList) |
Map<Long,Data> |
QueueContainer.clear() |
Map<Long,Data> |
QueueContainer.compareAndRemove(Collection<Data> dataList,
boolean retain)
This method triggers store load
|
Map<Long,Data> |
QueueContainer.drain(int maxSize) |
List<Data> |
QueueContainer.getAsDataList()
This method triggers store load.
|
Map<Long,Data> |
QueueStoreWrapper.loadAll(Collection<Long> keys) |
Modifier and Type | Method and Description |
---|---|
long |
QueueContainer.offer(Data data) |
void |
QueueContainer.offerBackup(Data data,
long itemId) |
long |
QueueContainer.remove(Data data)
iterates all items, checks equality with data
This method does not trigger store load.
|
void |
QueueItem.setData(Data data) |
void |
QueueStoreWrapper.store(Long key,
Data value) |
boolean |
QueueContainer.txnCommitOffer(long itemId,
Data data,
boolean backup) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
QueueContainer.addAll(Collection<Data> dataList) |
void |
QueueContainer.addAllBackup(Map<Long,Data> dataMap) |
Map<Long,Data> |
QueueContainer.compareAndRemove(Collection<Data> dataList,
boolean retain)
This method triggers store load
|
boolean |
QueueContainer.contains(Collection<Data> dataSet)
This method does not trigger store load.
|
void |
QueueStoreWrapper.storeAll(Map<Long,Data> map) |
Constructor and Description |
---|
QueueEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
QueueItem(QueueContainer container,
long itemId,
Data data) |
Constructor and Description |
---|
QueueIterator(Iterator<Data> iterator,
SerializationService serializationService,
boolean binary) |
Constructor and Description |
---|
OfferRequest(String name,
Data data) |
OfferRequest(String name,
long timeoutMillis,
Data data) |
RemoveRequest(String name,
Data data) |
Constructor and Description |
---|
AddAllRequest(String name,
Collection<Data> dataList) |
CompareAndRemoveRequest(String name,
Collection<Data> dataList,
boolean retain) |
ContainsRequest(String name,
Collection<Data> dataList) |
Modifier and Type | Method and Description |
---|---|
void |
QueueOperation.publishEvent(ItemEventType eventType,
Data data) |
Constructor and Description |
---|
OfferBackupOperation(String name,
Data data,
long itemId) |
OfferOperation(String name,
long timeout,
Data data) |
RemoveOperation(String name,
Data data) |
Constructor and Description |
---|
AddAllBackupOperation(String name,
Map<Long,Data> dataMap) |
AddAllOperation(String name,
Collection<Data> dataList) |
CompareAndRemoveOperation(String name,
Collection<Data> dataList,
boolean retain) |
ContainsOperation(String name,
Collection<Data> dataList) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
SetContainer.addAll(List<Data> valueList) |
Modifier and Type | Method and Description |
---|---|
Map<Long,Data> |
SetContainer.addAll(List<Data> valueList) |
Modifier and Type | Field and Description |
---|---|
protected Data |
TxnCollectionRequest.value |
Constructor and Description |
---|
TxnCollectionRequest(String name,
Data value) |
Constructor and Description |
---|
CollectionReserveAddOperation(String name,
String transactionId,
Data value) |
CollectionReserveRemoveOperation(String name,
long reservedItemId,
Data value,
String transactionId) |
CollectionTxnAddBackupOperation(String name,
long itemId,
Data value) |
CollectionTxnAddOperation(String name,
long itemId,
Data value) |
Constructor and Description |
---|
TxnListAddRequest(String name,
Data value) |
TxnListRemoveRequest(String name,
Data value) |
Modifier and Type | Method and Description |
---|---|
Data |
TransactionalQueueProxySupport.peekInternal(long timeout) |
Data |
TransactionalQueueProxySupport.pollInternal(long timeout) |
Modifier and Type | Method and Description |
---|---|
boolean |
TransactionalQueueProxySupport.offerInternal(Data data,
long timeout) |
Constructor and Description |
---|
TxQueueItem(QueueContainer container,
long itemId,
Data data) |
Constructor and Description |
---|
TxnOfferRequest(String name,
long timeout,
Data data) |
Constructor and Description |
---|
TxnOfferBackupOperation(String name,
long itemId,
Data data) |
TxnOfferOperation(String name,
long itemId,
Data data) |
Constructor and Description |
---|
TxnSetAddRequest(String name,
Data value) |
TxnSetRemoveRequest(String name,
Data value) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractAlterRequest.function |
Constructor and Description |
---|
AbstractAlterRequest(String name,
Data function) |
AlterAndGetRequest(String name,
Data function) |
AlterRequest(String name,
Data function) |
ApplyRequest(String name,
Data function) |
GetAndAlterRequest(String name,
Data function) |
Modifier and Type | Method and Description |
---|---|
Data |
AtomicReferenceContainer.get() |
Data |
AtomicReferenceContainer.getAndSet(Data value) |
Modifier and Type | Method and Description |
---|---|
boolean |
AtomicReferenceContainer.compareAndSet(Data expect,
Data value) |
boolean |
AtomicReferenceContainer.contains(Data expected) |
Data |
AtomicReferenceContainer.getAndSet(Data value) |
void |
AtomicReferenceContainer.set(Data value) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractAlterRequest.function |
Constructor and Description |
---|
AbstractAlterRequest(String name,
Data function) |
AlterAndGetRequest(String name,
Data function) |
AlterRequest(String name,
Data function) |
ApplyRequest(String name,
Data function) |
CompareAndSetRequest(String name,
Data expected,
Data update) |
ContainsRequest(String name,
Data expected) |
GetAndAlterRequest(String name,
Data function) |
GetAndSetRequest(String name,
Data update) |
ModifyRequest(String name,
Data update) |
SetRequest(String name,
Data update) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractAlterOperation.backup |
protected Data |
AbstractAlterOperation.function |
protected Data |
ApplyOperation.function |
protected Data |
ApplyOperation.returnValue |
Constructor and Description |
---|
AbstractAlterOperation(String name,
Data function) |
AlterAndGetOperation(String name,
Data function) |
AlterOperation(String name,
Data function) |
ApplyOperation(String name,
Data function) |
CompareAndSetOperation(String name,
Data expect,
Data update) |
ContainsOperation(String name,
Data contains) |
GetAndAlterOperation(String name,
Data function) |
GetAndSetOperation(String name,
Data newValue) |
SetAndGetOperation(String name,
Data newValue) |
SetBackupOperation(String name,
Data newValue) |
SetOperation(String name,
Data newValue) |
Constructor and Description |
---|
AtomicReferenceReplicationOperation(Map<String,Data> migrationData) |
Modifier and Type | Method and Description |
---|---|
Data |
ConditionKey.getKey() |
Data |
LockResource.getKey() |
Data |
LockProxy.getKeyData() |
Modifier and Type | Method and Description |
---|---|
Set<Data> |
LockStoreProxy.getLockedKeys() |
Set<Data> |
LockStore.getLockedKeys() |
Set<Data> |
LockStoreImpl.getLockedKeys() |
Modifier and Type | Method and Description |
---|---|
boolean |
LockStoreImpl.addAwait(Data key,
String conditionId,
String caller,
long threadId) |
boolean |
LockStoreProxy.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
LockStore.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
LockStoreImpl.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
LockStoreProxy.extendLeaseTime(Data key,
String caller,
long threadId,
long leaseTime) |
boolean |
LockStore.extendLeaseTime(Data key,
String caller,
long threadId,
long leaseTime) |
boolean |
LockStoreImpl.extendLeaseTime(Data key,
String caller,
long threadId,
long leaseTime) |
boolean |
LockStoreProxy.forceUnlock(Data key) |
boolean |
LockStore.forceUnlock(Data dataKey) |
boolean |
LockStoreImpl.forceUnlock(Data key) |
void |
LockProxySupport.forceUnlock(NodeEngine nodeEngine,
Data key) |
int |
LockStoreImpl.getAwaitCount(Data key,
String conditionId) |
com.hazelcast.concurrent.lock.LockResourceImpl |
LockStoreImpl.getLock(Data key) |
int |
LockStoreProxy.getLockCount(Data key) |
int |
LockStore.getLockCount(Data key) |
int |
LockStoreImpl.getLockCount(Data key) |
int |
LockProxySupport.getLockCount(NodeEngine nodeEngine,
Data key) |
String |
LockStoreProxy.getOwnerInfo(Data dataKey) |
String |
LockStore.getOwnerInfo(Data dataKey) |
String |
LockStoreImpl.getOwnerInfo(Data key) |
long |
LockStoreProxy.getRemainingLeaseTime(Data key) |
long |
LockStore.getRemainingLeaseTime(Data key) |
long |
LockStoreImpl.getRemainingLeaseTime(Data key) |
long |
LockProxySupport.getRemainingLeaseTime(NodeEngine nodeEngine,
Data key) |
ConditionKey |
LockStoreImpl.getSignalKey(Data key) |
int |
LockStoreImpl.getVersion(Data key) |
boolean |
LockStoreProxy.isLocked(Data key) |
boolean |
LockStore.isLocked(Data key) |
boolean |
LockStoreImpl.isLocked(Data key) |
boolean |
LockProxySupport.isLocked(NodeEngine nodeEngine,
Data key) |
boolean |
LockStoreProxy.isLockedBy(Data key,
String caller,
long threadId) |
boolean |
LockStore.isLockedBy(Data key,
String caller,
long threadId) |
boolean |
LockStoreImpl.isLockedBy(Data key,
String caller,
long threadId) |
boolean |
LockProxySupport.isLockedByCurrentThread(NodeEngine nodeEngine,
Data key) |
boolean |
LockStoreProxy.isTransactionallyLocked(Data key) |
boolean |
LockStore.isTransactionallyLocked(Data key) |
boolean |
LockStoreImpl.isTransactionallyLocked(Data key) |
boolean |
LockStoreProxy.lock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStore.lock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStoreImpl.lock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
void |
LockProxySupport.lock(NodeEngine nodeEngine,
Data key) |
void |
LockProxySupport.lock(NodeEngine nodeEngine,
Data key,
long leaseTime) |
void |
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
Data key) |
void |
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
Data key,
long leaseTime) |
AwaitOperation |
LockStoreImpl.pollExpiredAwaitOp(Data key) |
boolean |
LockStoreImpl.removeAwait(Data key,
String conditionId,
String caller,
long threadId) |
boolean |
LockStoreImpl.startAwaiting(Data key,
String conditionId,
String caller,
long threadId) |
boolean |
LockProxySupport.tryLock(NodeEngine nodeEngine,
Data key) |
boolean |
LockProxySupport.tryLock(NodeEngine nodeEngine,
Data key,
long timeout,
TimeUnit timeunit) |
boolean |
LockProxySupport.tryLock(NodeEngine nodeEngine,
Data key,
long timeout,
TimeUnit timeunit,
long leaseTime,
TimeUnit leaseTimeunit) |
boolean |
LockStoreProxy.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStore.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStoreImpl.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long leaseTime) |
boolean |
LockStoreProxy.unlock(Data key,
String caller,
long threadId,
long referenceId) |
boolean |
LockStore.unlock(Data key,
String caller,
long threadId,
long referenceId) |
boolean |
LockStoreImpl.unlock(Data key,
String caller,
long threadId,
long referenceId) |
void |
LockProxySupport.unlock(NodeEngine nodeEngine,
Data key) |
Modifier and Type | Method and Description |
---|---|
void |
LockEvictionProcessor.process(EntryTaskScheduler<Data,Integer> scheduler,
Collection<ScheduledEntry<Data,Integer>> entries) |
void |
LockEvictionProcessor.process(EntryTaskScheduler<Data,Integer> scheduler,
Collection<ScheduledEntry<Data,Integer>> entries) |
Constructor and Description |
---|
ConditionKey(String name,
Data key,
String conditionId) |
LockWaitNotifyKey(ObjectNamespace namespace,
Data key) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractLockRequest.key |
protected Data |
AbstractUnlockRequest.key |
protected Data |
AbstractIsLockedRequest.key |
Constructor and Description |
---|
AbstractIsLockedRequest(Data key) |
AbstractIsLockedRequest(Data key,
long threadId) |
AbstractLockRequest(Data key,
long threadId) |
AbstractLockRequest(Data key,
long threadId,
long ttl,
long timeout) |
AbstractUnlockRequest(Data key,
long threadId) |
AbstractUnlockRequest(Data key,
long threadId,
boolean force) |
BeforeAwaitRequest(ObjectNamespace namespace,
long threadId,
String conditionId,
Data key) |
GetLockCountRequest(Data key) |
GetRemainingLeaseRequest(Data key) |
IsLockedRequest(Data key) |
IsLockedRequest(Data key,
long threadId) |
LockRequest(Data key,
long threadId,
long ttl,
long timeout) |
UnlockRequest(Data key,
long threadId) |
UnlockRequest(Data key,
long threadId,
boolean force) |
Modifier and Type | Field and Description |
---|---|
protected Data |
BaseLockOperation.key |
Modifier and Type | Method and Description |
---|---|
Data |
BaseLockOperation.getKey() |
Constructor and Description |
---|
AwaitBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
String originalCaller) |
AwaitOperation(ObjectNamespace namespace,
Data key,
long threadId,
long timeout,
String conditionId) |
BaseLockOperation(ObjectNamespace namespace,
Data key,
long threadId) |
BaseLockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long timeout) |
BaseLockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
long timeout) |
BeforeAwaitBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
String originalCaller) |
BeforeAwaitOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId) |
GetLockCountOperation(ObjectNamespace namespace,
Data key) |
GetRemainingLeaseTimeOperation(ObjectNamespace namespace,
Data key) |
IsLockedOperation(ObjectNamespace namespace,
Data key) |
IsLockedOperation(ObjectNamespace namespace,
Data key,
long threadId) |
LocalLockCleanupOperation(ObjectNamespace namespace,
Data key,
String uuid) |
LockBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
String originalCallerUuid) |
LockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long leaseTime,
long timeout) |
SignalBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
boolean all) |
SignalOperation(ObjectNamespace namespace,
Data key,
long threadId,
String conditionId,
boolean all) |
UnlockBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String originalCallerUuid,
boolean force) |
UnlockIfLeaseExpiredOperation(ObjectNamespace namespace,
Data key,
int version) |
UnlockOperation(ObjectNamespace namespace,
Data key,
long threadId) |
UnlockOperation(ObjectNamespace namespace,
Data key,
long threadId,
boolean force) |
Constructor and Description |
---|
CallableTaskOperation(String name,
String uuid,
Data callableData) |
MemberCallableTaskOperation(String name,
String uuid,
Data callableData) |
Modifier and Type | Method and Description |
---|---|
<B extends Data> |
SerializationService.toData(Object obj) |
<B extends Data> |
SerializationService.toData(Object obj,
PartitioningStrategy strategy) |
Modifier and Type | Method and Description |
---|---|
BufferObjectDataInput |
InputOutputFactory.createInput(Data data,
SerializationService service) |
BufferObjectDataInput |
SerializationService.createObjectDataInput(Data data) |
PortableReader |
SerializationService.createPortableReader(Data data) |
void |
SerializationService.disposeData(Data data) |
ClassDefinition |
PortableContext.lookupClassDefinition(Data data) |
Modifier and Type | Class and Description |
---|---|
class |
HeapData
A
Data implementation where the content lives on the heap. |
Modifier and Type | Method and Description |
---|---|
Data |
ObjectDataInputStream.readData() |
Data |
AbstractSerializationService.toData(Object obj) |
Data |
AbstractSerializationService.toData(Object obj,
PartitioningStrategy strategy) |
Modifier and Type | Method and Description |
---|---|
BufferObjectDataInput |
AbstractSerializationService.createObjectDataInput(Data data) |
PortableReader |
SerializationServiceV1.createPortableReader(Data data) |
void |
AbstractSerializationService.disposeData(Data data) |
void |
ObjectDataOutputStream.writeData(Data data) |
Modifier and Type | Method and Description |
---|---|
BufferObjectDataInput |
BufferPool.takeInputBuffer(Data data)
Takes an BufferObjectDataInput from the pool and initializes it with the given data.
|
BufferObjectDataInput |
BufferPoolImpl.takeInputBuffer(Data data) |
Modifier and Type | Field and Description |
---|---|
protected Data |
EntryEventFilter.key |
Modifier and Type | Field and Description |
---|---|
protected IFunction<Object,Data> |
MapContainer.toDataFunction |
Modifier and Type | Method and Description |
---|---|
Data |
EntryEventFilter.getKey() |
Data |
DataAwareEntryEvent.getKeyData() |
Data |
DataAwareEntryEvent.getMergingValueData() |
Data |
DataAwareEntryEvent.getNewValueData() |
Data |
DataAwareEntryEvent.getOldValueData() |
Data |
MapServiceContext.toData(Object object) |
Data |
MapServiceContext.toData(Object object,
PartitioningStrategy partitionStrategy) |
Modifier and Type | Method and Description |
---|---|
Collection<Map.Entry<Data,Data>> |
MapEntries.entries() |
Collection<Map.Entry<Data,Data>> |
MapEntries.entries() |
Set<Data> |
MapKeySet.getKeySet() |
Collection<Data> |
MapValueCollection.getValues() |
Iterator<Map.Entry<Data,Data>> |
MapEntries.iterator() |
Iterator<Map.Entry<Data,Data>> |
MapEntries.iterator() |
IFunction<Object,Data> |
MapContainer.toData() |
Modifier and Type | Method and Description |
---|---|
void |
MapEntries.add(Data key,
Data value) |
protected int |
LocalMapStatsProvider.isLocked(Data key,
RecordStore recordStore)
Return 1 if locked, otherwise 0.
|
QueryableEntry |
MapContainer.newQueryEntry(Data key,
Object value) |
Modifier and Type | Method and Description |
---|---|
void |
MapEntries.add(Map.Entry<Data,Data> entry) |
void |
MapEntries.add(Map.Entry<Data,Data> entry) |
Constructor and Description |
---|
DataAwareEntryEvent(Member from,
int eventType,
String source,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
Data dataMergingValue,
SerializationService serializationService) |
EntryEventFilter(boolean includeValue,
Data key) |
MapRecordKey(String mapName,
Data key) |
Constructor and Description |
---|
MapEntries(Collection<Map.Entry<Data,Data>> entries) |
MapEntries(Collection<Map.Entry<Data,Data>> entries) |
MapKeyLoader(String mapName,
OperationService opService,
InternalPartitionService ps,
ExecutionService execService,
IFunction<Object,Data> serialize) |
MapKeySet(Set<Data> keySet) |
MapValueCollection(Collection<Data> values) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractMapAddEntryListenerRequest.key |
protected Data |
MapPutRequest.key |
protected Data |
MapRemoveRequest.key |
protected Data |
MapRemoveIfSameRequest.key |
protected Data |
MapTryRemoveRequest.key |
protected Data |
MapDeleteRequest.key |
protected Data |
MapPutRequest.value |
protected Data |
MapRemoveIfSameRequest.value |
Constructor and Description |
---|
AbstractMapAddEntryListenerRequest(String name,
Data key,
boolean includeValue,
int listenerFlags) |
AbstractTxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key) |
AbstractTxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key,
Data value) |
AbstractTxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key,
Data value,
Data newValue) |
AbstractTxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key,
Data value,
long ttl,
TimeUnit timeUnit) |
MapAddEntryListenerRequest(String name,
Data key,
boolean includeValue,
Predicate predicate,
int listenerFlags) |
MapAddEntryListenerSqlRequest(String name,
Data key,
boolean includeValue,
int listenerFlags) |
MapAddEntryListenerSqlRequest(String name,
Data key,
boolean includeValue,
String predicate,
int listenerFlags) |
MapContainsKeyRequest(String name,
Data key) |
MapContainsKeyRequest(String name,
Data keyData,
long threadId) |
MapContainsValueRequest(String name,
Data value) |
MapDeleteRequest(String name,
Data key,
long threadId) |
MapEvictRequest(String name,
Data key,
long threadId) |
MapExecuteOnKeyRequest(String name,
EntryProcessor processor,
Data key,
long threadId) |
MapGetEntryViewRequest(String name,
Data key,
long threadId) |
MapGetRequest(String name,
Data key) |
MapGetRequest(String name,
Data key,
long threadId) |
MapIsLockedRequest(String name,
Data key) |
MapLockRequest(String name,
Data key,
long threadId) |
MapLockRequest(String name,
Data key,
long threadId,
long ttl,
long timeout) |
MapPutIfAbsentRequest(String name,
Data key,
Data value,
long threadId) |
MapPutIfAbsentRequest(String name,
Data key,
Data value,
long threadId,
long ttl) |
MapPutRequest(String name,
Data key,
Data value,
long threadId) |
MapPutRequest(String name,
Data key,
Data value,
long threadId,
long ttl) |
MapPutTransientRequest(String name,
Data key,
Data value,
long threadId) |
MapPutTransientRequest(String name,
Data key,
Data value,
long threadId,
long ttl) |
MapRemoveIfSameRequest(String name,
Data key,
Data value,
long threadId) |
MapRemoveRequest(String name,
Data key,
long threadId) |
MapReplaceIfSameRequest(String name,
Data key,
Data testValue,
Data value,
long threadId) |
MapReplaceRequest(String name,
Data key,
Data value,
long threadId) |
MapSetRequest(String name,
Data key,
Data value,
long threadId) |
MapSetRequest(String name,
Data key,
Data value,
long threadId,
long ttl) |
MapTryPutRequest(String name,
Data key,
Data value,
long threadId,
long timeout) |
MapTryRemoveRequest(String name,
Data key,
long threadId,
long timeout) |
MapUnlockRequest(String name,
Data key,
long threadId) |
MapUnlockRequest(String name,
Data key,
long threadId,
boolean force) |
TxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key) |
TxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key,
Data value) |
TxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key,
Data value,
Data newValue) |
TxnMapRequest(String name,
AbstractTxnMapRequest.TxnMapRequestType requestType,
Data key,
Data value,
long ttl,
TimeUnit timeUnit) |
Constructor and Description |
---|
MapExecuteOnKeysRequest(String name,
EntryProcessor processor,
Set<Data> keys) |
MapGetAllRequest(String name,
List<Data> keys,
int partitionId) |
MapLoadGivenKeysRequest(String name,
List<Data> keys,
boolean replaceExistingValues) |
Modifier and Type | Field and Description |
---|---|
protected Data |
EntryEventData.dataKey |
protected Data |
EntryEventData.dataMergingValue |
protected Data |
EntryEventData.dataNewValue |
protected Data |
EntryEventData.dataOldValue |
Modifier and Type | Method and Description |
---|---|
Data |
EntryEventData.getDataKey() |
Data |
EntryEventData.getDataMergingValue() |
Data |
EntryEventData.getDataNewValue() |
Data |
EntryEventData.getDataOldValue() |
Modifier and Type | Method and Description |
---|---|
protected boolean |
MapEventPublisherImpl.doFilter(EventFilter filter,
Data dataKey,
Object dataOldValue,
Object dataValue,
EntryEventType eventType,
String mapNameOrNull) |
void |
MapEventPublisherImpl.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object dataOldValue,
Object dataValue) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object dataOldValue,
Object dataValue) |
void |
MapEventPublisherImpl.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object oldValue,
Object value,
Object mergingValue) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object dataOldValue,
Object dataValue,
Object dataMergingValue) |
void |
MapEventPublisherImpl.publishWanReplicationRemove(String mapName,
Data key,
long removeTime) |
void |
MapEventPublisher.publishWanReplicationRemove(String mapName,
Data key,
long removeTime) |
void |
MapEventPublisherImpl.publishWanReplicationRemoveBackup(String mapName,
Data key,
long removeTime) |
void |
MapEventPublisher.publishWanReplicationRemoveBackup(String mapName,
Data key,
long removeTime) |
Constructor and Description |
---|
EntryEventData(String source,
String mapName,
Address caller,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
Data dataMergingValue,
int eventType) |
EntryEventData(String source,
String mapName,
Address caller,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
int eventType) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
EvictorImpl.tryEvict(Data key,
Record record,
RecordStore recordStore,
boolean backup,
long now) |
Modifier and Type | Method and Description |
---|---|
protected Data |
AbstractMapDataStore.toData(Object obj) |
Modifier and Type | Method and Description |
---|---|
Collection<Data> |
MapDataStore.flush()
Flushes all keys in this map-store.
|
Modifier and Type | Method and Description |
---|---|
Collection<Data> |
WriteBehindStore.flush() |
Modifier and Type | Method and Description |
---|---|
Object |
WriteBehindStore.add(Data key,
Object value,
long now) |
Object |
WriteBehindStore.addBackup(Data key,
Object value,
long time) |
void |
WriteBehindStore.addTransient(Data key,
long now) |
Object |
WriteBehindStore.flush(Data key,
Object value,
boolean backup) |
Object |
WriteBehindStore.load(Data key) |
boolean |
WriteBehindStore.loadable(Data key)
* Used in
IMap.loadAll(boolean) calls. |
void |
WriteBehindStore.remove(Data key,
long now) |
void |
WriteBehindStore.removeBackup(Data key,
long time) |
Modifier and Type | Method and Description |
---|---|
void |
WriteBehindStore.add(DelayedEntry<Data,Object> delayedEntry) |
Modifier and Type | Method and Description |
---|---|
Collection<Data> |
WriteThroughStore.flush() |
Modifier and Type | Method and Description |
---|---|
Object |
WriteThroughStore.add(Data key,
Object value,
long time) |
Object |
WriteThroughStore.addBackup(Data key,
Object value,
long time) |
void |
WriteThroughStore.addTransient(Data key,
long now) |
Object |
WriteThroughStore.flush(Data key,
Object value,
boolean backup) |
Object |
WriteThroughStore.load(Data key) |
boolean |
WriteThroughStore.loadable(Data key) |
void |
WriteThroughStore.remove(Data key,
long time) |
void |
WriteThroughStore.removeBackup(Data key,
long time) |
Modifier and Type | Method and Description |
---|---|
Data |
SingleNearCacheInvalidation.getKey() |
protected Data |
AbstractNearCacheInvalidator.toHeapData(Data key) |
Modifier and Type | Method and Description |
---|---|
static List<Data> |
BatchInvalidator.getKeys(BatchNearCacheInvalidation batch) |
static List<Data> |
BatchInvalidator.getKeysExcludingSource(BatchNearCacheInvalidation batch,
String excludedSourceUuid) |
Modifier and Type | Method and Description |
---|---|
void |
BatchInvalidator.accumulateOrInvalidate(String mapName,
Data key,
List<Data> keys,
String sourceUuid) |
static MapOperation |
AbstractNearCacheInvalidator.createSingleOrBatchInvalidationOperation(String mapName,
Data key,
List<Data> keys) |
Object |
NearCacheImpl.get(Data key) |
Object |
NearCacheProvider.getFromNearCache(String mapName,
Data key) |
void |
NearCacheInvalidator.invalidate(String mapName,
Data key,
String sourceUuid)
Invalidates local and remote near-caches.
|
void |
NonStopInvalidator.invalidate(String mapName,
Data key,
String sourceUuid) |
void |
BatchInvalidator.invalidate(String mapName,
Data key,
String sourceUuid) |
protected void |
NonStopInvalidator.invalidateClient(String mapName,
Data key,
List<Data> keys,
String sourceUuid) |
void |
AbstractNearCacheInvalidator.invalidateLocal(String mapName,
Data key,
List<Data> keys) |
protected void |
NonStopInvalidator.invalidateMember(String mapName,
Data key,
List<Data> keys,
String sourceUuid) |
void |
NearCacheImpl.put(Data key,
Object value) |
boolean |
NearCacheImpl.remove(Data key) |
protected Data |
AbstractNearCacheInvalidator.toHeapData(Data key) |
Modifier and Type | Method and Description |
---|---|
void |
BatchInvalidator.accumulateOrInvalidate(String mapName,
Data key,
List<Data> keys,
String sourceUuid) |
static MapOperation |
AbstractNearCacheInvalidator.createSingleOrBatchInvalidationOperation(String mapName,
Data key,
List<Data> keys) |
void |
NearCacheInvalidator.invalidate(String mapName,
List<Data> keys,
String sourceUuid)
Invalidates local and remote near-caches.
|
void |
NonStopInvalidator.invalidate(String mapName,
List<Data> keys,
String sourceUuid) |
void |
BatchInvalidator.invalidate(String mapName,
List<Data> keys,
String sourceUuid) |
protected void |
NonStopInvalidator.invalidateClient(String mapName,
Data key,
List<Data> keys,
String sourceUuid) |
void |
AbstractNearCacheInvalidator.invalidateLocal(String mapName,
Data key,
List<Data> keys) |
protected void |
NonStopInvalidator.invalidateMember(String mapName,
Data key,
List<Data> keys,
String sourceUuid) |
Constructor and Description |
---|
SingleNearCacheInvalidation(String mapName,
Data key,
String sourceUuid) |
Modifier and Type | Field and Description |
---|---|
protected Data |
KeyBasedMapOperation.dataKey |
protected Data |
BasePutOperation.dataOldValue |
protected Data |
BaseRemoveOperation.dataOldValue |
protected Data |
KeyBasedMapOperation.dataValue |
Modifier and Type | Method and Description |
---|---|
Data |
KeyBasedMapOperation.getKey() |
Data |
KeyBasedMapOperation.getValue() |
Modifier and Type | Method and Description |
---|---|
MapOperation |
MapOperationProvider.createContainsKeyOperation(String name,
Data dataKey) |
MapOperation |
DefaultMapOperationProvider.createContainsKeyOperation(String name,
Data dataKey) |
MapOperation |
MapOperationProviderDelegator.createContainsKeyOperation(String name,
Data dataKey) |
OperationFactory |
MapOperationProvider.createContainsValueOperationFactory(String name,
Data testValue) |
OperationFactory |
DefaultMapOperationProvider.createContainsValueOperationFactory(String name,
Data testValue) |
OperationFactory |
MapOperationProviderDelegator.createContainsValueOperationFactory(String name,
Data testValue) |
MapOperation |
WANAwareOperationProvider.createDeleteOperation(String name,
Data key) |
MapOperation |
MapOperationProvider.createDeleteOperation(String name,
Data key) |
MapOperation |
DefaultMapOperationProvider.createDeleteOperation(String name,
Data key) |
MapOperation |
MapOperationProviderDelegator.createDeleteOperation(String name,
Data key) |
MapOperation |
WANAwareOperationProvider.createEntryOperation(String name,
Data dataKey,
EntryProcessor entryProcessor) |
MapOperation |
MapOperationProvider.createEntryOperation(String name,
Data dataKey,
EntryProcessor entryProcessor) |
MapOperation |
DefaultMapOperationProvider.createEntryOperation(String name,
Data dataKey,
EntryProcessor entryProcessor) |
MapOperation |
MapOperationProviderDelegator.createEntryOperation(String name,
Data dataKey,
EntryProcessor entryProcessor) |
MapOperation |
MapOperationProvider.createEvictOperation(String name,
Data dataKey,
boolean asyncBackup) |
MapOperation |
DefaultMapOperationProvider.createEvictOperation(String name,
Data dataKey,
boolean asyncBackup) |
MapOperation |
MapOperationProviderDelegator.createEvictOperation(String name,
Data dataKey,
boolean asyncBackup) |
MapOperation |
MapOperationProvider.createGetEntryViewOperation(String name,
Data dataKey) |
MapOperation |
DefaultMapOperationProvider.createGetEntryViewOperation(String name,
Data dataKey) |
MapOperation |
MapOperationProviderDelegator.createGetEntryViewOperation(String name,
Data dataKey) |
MapOperation |
MapOperationProvider.createGetOperation(String name,
Data dataKey) |
MapOperation |
DefaultMapOperationProvider.createGetOperation(String name,
Data dataKey) |
MapOperation |
MapOperationProviderDelegator.createGetOperation(String name,
Data dataKey) |
MapOperation |
MapOperationProvider.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
DefaultMapOperationProvider.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
MapOperationProviderDelegator.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
WANAwareOperationProvider.createPutIfAbsentOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
MapOperationProvider.createPutIfAbsentOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
DefaultMapOperationProvider.createPutIfAbsentOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
MapOperationProviderDelegator.createPutIfAbsentOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
WANAwareOperationProvider.createPutOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
MapOperationProvider.createPutOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
DefaultMapOperationProvider.createPutOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
MapOperationProviderDelegator.createPutOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
WANAwareOperationProvider.createPutTransientOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
MapOperationProvider.createPutTransientOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
DefaultMapOperationProvider.createPutTransientOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
MapOperationProviderDelegator.createPutTransientOperation(String name,
Data key,
Data value,
long ttl) |
MapOperation |
WANAwareOperationProvider.createRemoveIfSameOperation(String name,
Data dataKey,
Data value) |
MapOperation |
MapOperationProvider.createRemoveIfSameOperation(String name,
Data dataKey,
Data value) |
MapOperation |
DefaultMapOperationProvider.createRemoveIfSameOperation(String name,
Data dataKey,
Data value) |
MapOperation |
MapOperationProviderDelegator.createRemoveIfSameOperation(String name,
Data dataKey,
Data value) |
MapOperation |
WANAwareOperationProvider.createRemoveOperation(String name,
Data key,
boolean disableWanReplicationEvent) |
MapOperation |
MapOperationProvider.createRemoveOperation(String name,
Data key,
boolean disableWanReplicationEvent) |
MapOperation |
DefaultMapOperationProvider.createRemoveOperation(String name,
Data key,
boolean disableWanReplicationEvent) |
MapOperation |
MapOperationProviderDelegator.createRemoveOperation(String name,
Data key,
boolean disableWanReplicationEvent) |
MapOperation |
WANAwareOperationProvider.createReplaceIfSameOperation(String name,
Data dataKey,
Data expect,
Data update) |
MapOperation |
MapOperationProvider.createReplaceIfSameOperation(String name,
Data dataKey,
Data expect,
Data update) |
MapOperation |
DefaultMapOperationProvider.createReplaceIfSameOperation(String name,
Data dataKey,
Data expect,
Data update) |
MapOperation |
MapOperationProviderDelegator.createReplaceIfSameOperation(String name,
Data dataKey,
Data expect,
Data update) |
MapOperation |
WANAwareOperationProvider.createReplaceOperation(String name,
Data dataKey,
Data value) |
MapOperation |
MapOperationProvider.createReplaceOperation(String name,
Data dataKey,
Data value) |
MapOperation |
DefaultMapOperationProvider.createReplaceOperation(String name,
Data dataKey,
Data value) |
MapOperation |
MapOperationProviderDelegator.createReplaceOperation(String name,
Data dataKey,
Data value) |
MapOperation |
WANAwareOperationProvider.createSetOperation(String name,
Data dataKey,
Data value,
long ttl) |
MapOperation |
MapOperationProvider.createSetOperation(String name,
Data dataKey,
Data value,
long ttl) |
MapOperation |
DefaultMapOperationProvider.createSetOperation(String name,
Data dataKey,
Data value,
long ttl) |
MapOperation |
MapOperationProviderDelegator.createSetOperation(String name,
Data dataKey,
Data value,
long ttl) |
MapOperation |
WANAwareOperationProvider.createTryPutOperation(String name,
Data dataKey,
Data value,
long timeout) |
MapOperation |
MapOperationProvider.createTryPutOperation(String name,
Data dataKey,
Data value,
long timeout) |
MapOperation |
DefaultMapOperationProvider.createTryPutOperation(String name,
Data dataKey,
Data value,
long timeout) |
MapOperation |
MapOperationProviderDelegator.createTryPutOperation(String name,
Data dataKey,
Data value,
long timeout) |
MapOperation |
WANAwareOperationProvider.createTryRemoveOperation(String name,
Data dataKey,
long timeout) |
MapOperation |
MapOperationProvider.createTryRemoveOperation(String name,
Data dataKey,
long timeout) |
MapOperation |
DefaultMapOperationProvider.createTryRemoveOperation(String name,
Data dataKey,
long timeout) |
MapOperation |
MapOperationProviderDelegator.createTryRemoveOperation(String name,
Data dataKey,
long timeout) |
MapOperation |
WANAwareOperationProvider.createTxnDeleteOperation(String name,
Data dataKey,
long version) |
MapOperation |
MapOperationProvider.createTxnDeleteOperation(String name,
Data dataKey,
long version) |
MapOperation |
DefaultMapOperationProvider.createTxnDeleteOperation(String name,
Data dataKey,
long version) |
MapOperation |
MapOperationProviderDelegator.createTxnDeleteOperation(String name,
Data dataKey,
long version) |
MapOperation |
MapOperationProvider.createTxnLockAndGetOperation(String name,
Data dataKey,
long timeout,
long ttl,
String ownerUuid,
boolean shouldLoad) |
MapOperation |
DefaultMapOperationProvider.createTxnLockAndGetOperation(String name,
Data dataKey,
long timeout,
long ttl,
String ownerUuid,
boolean shouldLoad) |
MapOperation |
MapOperationProviderDelegator.createTxnLockAndGetOperation(String name,
Data dataKey,
long timeout,
long ttl,
String ownerUuid,
boolean shouldLoad) |
MapOperation |
WANAwareOperationProvider.createTxnSetOperation(String name,
Data dataKey,
Data value,
long version,
long ttl) |
MapOperation |
MapOperationProvider.createTxnSetOperation(String name,
Data dataKey,
Data value,
long version,
long ttl) |
MapOperation |
DefaultMapOperationProvider.createTxnSetOperation(String name,
Data dataKey,
Data value,
long version,
long ttl) |
MapOperation |
MapOperationProviderDelegator.createTxnSetOperation(String name,
Data dataKey,
Data value,
long version,
long ttl) |
protected void |
MapOperation.invalidateNearCache(Data key) |
Modifier and Type | Method and Description |
---|---|
OperationFactory |
MapOperationProvider.createGetAllOperationFactory(String name,
List<Data> keys) |
OperationFactory |
DefaultMapOperationProvider.createGetAllOperationFactory(String name,
List<Data> keys) |
OperationFactory |
MapOperationProviderDelegator.createGetAllOperationFactory(String name,
List<Data> keys) |
MapOperation |
MapOperationProvider.createLoadAllOperation(String name,
List<Data> keys,
boolean replaceExistingValues) |
MapOperation |
DefaultMapOperationProvider.createLoadAllOperation(String name,
List<Data> keys,
boolean replaceExistingValues) |
MapOperation |
MapOperationProviderDelegator.createLoadAllOperation(String name,
List<Data> keys,
boolean replaceExistingValues) |
OperationFactory |
MapOperationProvider.createLoadAllOperationFactory(String name,
List<Data> keys,
boolean replaceExistingValues) |
OperationFactory |
DefaultMapOperationProvider.createLoadAllOperationFactory(String name,
List<Data> keys,
boolean replaceExistingValues) |
OperationFactory |
MapOperationProviderDelegator.createLoadAllOperationFactory(String name,
List<Data> keys,
boolean replaceExistingValues) |
MapOperation |
MapOperationProvider.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
MapOperationProvider.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
DefaultMapOperationProvider.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
DefaultMapOperationProvider.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
MapOperationProviderDelegator.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
MapOperation |
MapOperationProviderDelegator.createMergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
OperationFactory |
WANAwareOperationProvider.createMultipleEntryOperationFactory(String name,
Set<Data> keys,
EntryProcessor entryProcessor) |
OperationFactory |
MapOperationProvider.createMultipleEntryOperationFactory(String name,
Set<Data> keys,
EntryProcessor entryProcessor) |
OperationFactory |
DefaultMapOperationProvider.createMultipleEntryOperationFactory(String name,
Set<Data> keys,
EntryProcessor entryProcessor) |
OperationFactory |
MapOperationProviderDelegator.createMultipleEntryOperationFactory(String name,
Set<Data> keys,
EntryProcessor entryProcessor) |
MapOperation |
WANAwareOperationProvider.createPutFromLoadAllOperation(String name,
List<Data> keyValueSequence) |
MapOperation |
MapOperationProvider.createPutFromLoadAllOperation(String name,
List<Data> keyValueSequence) |
MapOperation |
DefaultMapOperationProvider.createPutFromLoadAllOperation(String name,
List<Data> keyValueSequence) |
MapOperation |
MapOperationProviderDelegator.createPutFromLoadAllOperation(String name,
List<Data> keyValueSequence) |
protected void |
MapOperation.invalidateNearCache(List<Data> keys) |
Constructor and Description |
---|
BasePutOperation(String name,
Data dataKey,
Data value) |
BasePutOperation(String name,
Data dataKey,
Data value,
long ttl) |
BaseRemoveOperation(String name,
Data dataKey) |
BaseRemoveOperation(String name,
Data dataKey,
boolean disableWanReplicationEvent) |
ContainsKeyOperation(String name,
Data dataKey) |
ContainsValueOperation(String name,
Data testValue) |
ContainsValueOperationFactory(String name,
Data value) |
DeleteOperation(String name,
Data dataKey) |
EntryBackupOperation(String name,
Data dataKey,
EntryBackupProcessor entryProcessor) |
EntryOperation(String name,
Data dataKey,
EntryProcessor entryProcessor) |
EvictOperation(String name,
Data dataKey,
boolean asyncBackup) |
GetEntryViewOperation(String name,
Data dataKey) |
GetOperation(String name,
Data dataKey) |
KeyBasedMapOperation(String name,
Data dataKey) |
KeyBasedMapOperation(String name,
Data dataKey,
Data dataValue) |
KeyBasedMapOperation(String name,
Data dataKey,
Data dataValue,
long ttl) |
KeyBasedMapOperation(String name,
Data dataKey,
long ttl) |
LockAwareOperation(String name,
Data dataKey) |
LockAwareOperation(String name,
Data dataKey,
Data dataValue,
long ttl) |
LockAwareOperation(String name,
Data dataKey,
long ttl) |
MergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy) |
MergeOperation(String name,
Data dataKey,
EntryView<Data,Data> entryView,
MapMergePolicy policy,
boolean disableWanReplicationEvent) |
NearCacheSingleInvalidationOperation(String mapName,
Data key) |
PutBackupOperation(String name,
Data dataKey,
Data dataValue,
RecordInfo recordInfo) |
PutBackupOperation(String name,
Data dataKey,
Data dataValue,
RecordInfo recordInfo,
boolean putTransient) |
PutBackupOperation(String name,
Data dataKey,
Data dataValue,
RecordInfo recordInfo,
boolean unlockKey,
boolean putTransient) |
PutBackupOperation(String name,
Data dataKey,
Data dataValue,
RecordInfo recordInfo,
boolean unlockKey,
boolean putTransient,
boolean disableWanReplicationEvent) |
PutIfAbsentOperation(String name,
Data dataKey,
Data value,
long ttl) |
PutOperation(String name,
Data dataKey,
Data value,
long ttl) |
PutTransientOperation(String name,
Data dataKey,
Data value,
long ttl) |
RemoveBackupOperation(String name,
Data dataKey) |
RemoveBackupOperation(String name,
Data dataKey,
boolean unlockKey) |
RemoveBackupOperation(String name,
Data dataKey,
boolean unlockKey,
boolean disableWanReplicationEvent) |
RemoveIfSameOperation(String name,
Data dataKey,
Data value) |
RemoveOperation(String name,
Data dataKey,
boolean disableWanReplicationEvent) |
ReplaceIfSameOperation(String name,
Data dataKey,
Data expect,
Data update) |
ReplaceOperation(String name,
Data dataKey,
Data value) |
SetOperation(String name,
Data dataKey,
Data value,
long ttl) |
TryPutOperation(String name,
Data dataKey,
Data value,
long timeout) |
TryRemoveOperation(String name,
Data dataKey,
long timeout) |
Modifier and Type | Method and Description |
---|---|
Data |
NearCachedMapProxyImpl.executeOnKeyInternal(Data key,
EntryProcessor entryProcessor) |
protected Data |
NearCachedMapProxyImpl.putIfAbsentInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected Data |
NearCachedMapProxyImpl.putInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected Data |
NearCachedMapProxyImpl.removeInternal(Data key) |
protected Data |
NearCachedMapProxyImpl.replaceInternal(Data key,
Data value) |
Modifier and Type | Method and Description |
---|---|
protected ICompletableFuture<Data> |
NearCachedMapProxyImpl.getAsyncInternal(Data key) |
protected ICompletableFuture<Data> |
NearCachedMapProxyImpl.putAsyncInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected ICompletableFuture<Data> |
NearCachedMapProxyImpl.removeAsyncInternal(Data key) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
NearCachedMapProxyImpl.containsKeyInternal(Data keyData) |
protected void |
NearCachedMapProxyImpl.deleteInternal(Data key) |
protected boolean |
NearCachedMapProxyImpl.evictInternal(Data key) |
Data |
NearCachedMapProxyImpl.executeOnKeyInternal(Data key,
EntryProcessor entryProcessor) |
ICompletableFuture |
NearCachedMapProxyImpl.executeOnKeyInternal(Data key,
EntryProcessor entryProcessor,
ExecutionCallback callback) |
protected ICompletableFuture<Data> |
NearCachedMapProxyImpl.getAsyncInternal(Data key) |
protected Object |
NearCachedMapProxyImpl.getCachedValue(Data key) |
protected Object |
NearCachedMapProxyImpl.getInternal(Data key) |
protected void |
NearCachedMapProxyImpl.invalidateCache(Data key) |
protected boolean |
NearCachedMapProxyImpl.isOwn(Data key) |
protected ICompletableFuture<Data> |
NearCachedMapProxyImpl.putAsyncInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected Data |
NearCachedMapProxyImpl.putIfAbsentInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected Data |
NearCachedMapProxyImpl.putInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected void |
NearCachedMapProxyImpl.putTransientInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected ICompletableFuture<Data> |
NearCachedMapProxyImpl.removeAsyncInternal(Data key) |
protected Data |
NearCachedMapProxyImpl.removeInternal(Data key) |
protected boolean |
NearCachedMapProxyImpl.removeInternal(Data key,
Data value) |
protected Data |
NearCachedMapProxyImpl.replaceInternal(Data key,
Data value) |
protected boolean |
NearCachedMapProxyImpl.replaceInternal(Data key,
Data expect,
Data update) |
protected void |
NearCachedMapProxyImpl.setInternal(Data key,
Data value,
long ttl,
TimeUnit timeunit) |
protected boolean |
NearCachedMapProxyImpl.tryPutInternal(Data key,
Data value,
long timeout,
TimeUnit timeunit) |
protected boolean |
NearCachedMapProxyImpl.tryRemoveInternal(Data key,
long timeout,
TimeUnit timeunit) |
Modifier and Type | Method and Description |
---|---|
void |
NearCachedMapProxyImpl.executeOnEntriesInternal(EntryProcessor entryProcessor,
Predicate predicate,
List<Data> resultingKeyValuePairs) |
Map |
NearCachedMapProxyImpl.executeOnKeysInternal(Set<Data> keys,
EntryProcessor entryProcessor) |
protected void |
NearCachedMapProxyImpl.getAllObjectInternal(List<Data> keys,
List resultingKeyValuePairs) |
protected void |
NearCachedMapProxyImpl.getCachedValue(List<Data> keys,
List<Object> resultingKeyValuePairs) |
protected void |
NearCachedMapProxyImpl.invalidateCache(Collection<Data> keys) |
protected void |
NearCachedMapProxyImpl.invalidateCache(Iterable<Data> keys) |
Modifier and Type | Method and Description |
---|---|
Data |
QueryResultRow.getKey() |
Data |
QueryResultRow.getValue() |
Data |
QueryResultRow.setValue(Data value) |
Modifier and Type | Method and Description |
---|---|
QueryableEntry |
QueryEntryFactory.newEntry(SerializationService serializationService,
Data key,
Object value,
Extractors extractors) |
Data |
QueryResultRow.setValue(Data value) |
Constructor and Description |
---|
QueryEventFilter(boolean includeValue,
Data key,
Predicate predicate) |
QueryResultRow(Data key,
Data valueData) |
Modifier and Type | Method and Description |
---|---|
Data |
DefaultQueryCacheEventData.getDataKey() |
Data |
QueryCacheEventData.getDataKey() |
Data |
DefaultQueryCacheEventData.getDataNewValue() |
Data |
QueryCacheEventData.getDataNewValue() |
Data |
DefaultQueryCacheEventData.getDataOldValue() |
Data |
QueryCacheEventData.getDataOldValue() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultQueryCacheEventData.setDataKey(Data dataKey) |
void |
DefaultQueryCacheEventData.setDataNewValue(Data dataNewValue) |
void |
DefaultQueryCacheEventData.setDataOldValue(Data dataOldValue) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractRecord.key |
Modifier and Type | Method and Description |
---|---|
Data |
Record.getKey() |
Data |
AbstractRecord.getKey() |
Data |
RecordReplicationInfo.getKey() |
Data |
RecordReplicationInfo.getValue() |
Modifier and Type | Method and Description |
---|---|
Record<Data> |
DataRecordFactory.newRecord(Object value) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRecord.setKey(Data key) |
Modifier and Type | Method and Description |
---|---|
void |
DataRecordFactory.setValue(Record<Data> record,
Object value) |
Constructor and Description |
---|
RecordReplicationInfo(Data key,
Data value,
RecordInfo recordInfo) |
Modifier and Type | Method and Description |
---|---|
Data |
RecordStore.readBackupData(Data key)
Called when
MapConfig.isReadBackupData() is true from
MapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)
Returns corresponding value for key as Data . |
Data |
DefaultRecordStore.readBackupData(Data key) |
Modifier and Type | Method and Description |
---|---|
protected List<Data> |
DefaultRecordStore.getKeysFromRecords(Collection<Record> clearableRecords) |
MapDataStore<Data,Object> |
RecordStore.getMapDataStore() |
MapDataStore<Data,Object> |
DefaultRecordStore.getMapDataStore() |
Set<Data> |
RecordStore.keySet() |
Set<Data> |
DefaultRecordStore.keySet() |
Modifier and Type | Method and Description |
---|---|
boolean |
RecordStore.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
DefaultRecordStore.canAcquireLock(Data key,
String caller,
long threadId) |
boolean |
RecordStore.containsKey(Data dataKey) |
boolean |
DefaultRecordStore.containsKey(Data key) |
boolean |
RecordStore.delete(Data dataKey) |
boolean |
DefaultRecordStore.delete(Data key) |
void |
RecordStore.doPostEvictionOperations(Data key,
Object value,
boolean isExpired) |
Object |
RecordStore.evict(Data key,
boolean backup) |
Object |
DefaultRecordStore.evict(Data key,
boolean backup) |
boolean |
RecordStore.extendLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
DefaultRecordStore.extendLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
RecordStore.forceUnlock(Data dataKey) |
boolean |
DefaultRecordStore.forceUnlock(Data dataKey) |
Object |
RecordStore.get(Data dataKey,
boolean backup)
Gets record from
RecordStore . |
Object |
DefaultRecordStore.get(Data key,
boolean backup) |
String |
RecordStore.getLockOwnerInfo(Data key) |
String |
DefaultRecordStore.getLockOwnerInfo(Data key) |
R |
RecordStore.getRecord(Data key) |
Record |
DefaultRecordStore.getRecord(Data key) |
R |
RecordStore.getRecordOrNull(Data key)
Returns live record or null if record is already expired.
|
Record |
DefaultRecordStore.getRecordOrNull(Data key) |
protected Record |
DefaultRecordStore.getRecordOrNull(Data key,
long now,
boolean backup) |
protected boolean |
DefaultRecordStore.isKeyAndValueLoadable(Data key,
Object value) |
boolean |
RecordStore.isLocked(Data key) |
boolean |
DefaultRecordStore.isLocked(Data dataKey) |
boolean |
RecordStore.isTransactionallyLocked(Data key) |
boolean |
DefaultRecordStore.isTransactionallyLocked(Data key) |
Record |
RecordStore.loadRecordOrNull(Data key,
boolean backup) |
Record |
DefaultRecordStore.loadRecordOrNull(Data key,
boolean backup) |
boolean |
RecordStore.merge(Data dataKey,
EntryView mergingEntryView,
MapMergePolicy mergePolicy) |
boolean |
DefaultRecordStore.merge(Data key,
EntryView mergingEntry,
MapMergePolicy mergePolicy) |
Object |
RecordStore.put(Data dataKey,
Object dataValue,
long ttl) |
Object |
DefaultRecordStore.put(Data key,
Object value,
long ttl) |
R |
RecordStore.putBackup(Data key,
Object value) |
Record |
DefaultRecordStore.putBackup(Data key,
Object value) |
R |
RecordStore.putBackup(Data key,
Object value,
long ttl,
boolean putTransient) |
Record |
DefaultRecordStore.putBackup(Data key,
Object value,
long ttl,
boolean putTransient) |
Object |
RecordStore.putFromLoad(Data key,
Object value)
Puts key-value pair to map which is the result of a load from map store operation.
|
Object |
DefaultRecordStore.putFromLoad(Data key,
Object value) |
Object |
RecordStore.putFromLoad(Data key,
Object value,
long ttl)
Puts key-value pair to map which is the result of a load from map store operation.
|
Object |
DefaultRecordStore.putFromLoad(Data key,
Object value,
long ttl) |
Object |
RecordStore.putFromLoadBackup(Data key,
Object value)
Puts key-value pair to map which is the result of a load from map store operation on backup.
|
Object |
DefaultRecordStore.putFromLoadBackup(Data key,
Object value) |
Object |
RecordStore.putIfAbsent(Data dataKey,
Object value,
long ttl) |
Object |
DefaultRecordStore.putIfAbsent(Data key,
Object value,
long ttl) |
protected Object |
DefaultRecordStore.putInternal(Data key,
Object value,
long ttl,
boolean loadFromStore) |
void |
RecordStore.putRecord(Data key,
R record)
Puts a data key and a record value to record-store.
|
void |
DefaultRecordStore.putRecord(Data key,
Record record) |
void |
RecordStore.putTransient(Data dataKey,
Object value,
long ttl) |
void |
DefaultRecordStore.putTransient(Data key,
Object value,
long ttl) |
Data |
RecordStore.readBackupData(Data key)
Called when
MapConfig.isReadBackupData() is true from
MapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)
Returns corresponding value for key as Data . |
Data |
DefaultRecordStore.readBackupData(Data key) |
Object |
RecordStore.remove(Data dataKey) |
Object |
DefaultRecordStore.remove(Data key) |
boolean |
RecordStore.remove(Data dataKey,
Object testValue) |
boolean |
DefaultRecordStore.remove(Data key,
Object testValue) |
void |
RecordStore.removeBackup(Data dataKey)
Similar to
RecordStore.remove(com.hazelcast.nio.serialization.Data)
except removeBackup doesn't touch mapstore since it does not return previous value. |
void |
DefaultRecordStore.removeBackup(Data key) |
protected Object |
DefaultRecordStore.removeRecord(Data key,
Record record,
long now) |
Object |
RecordStore.replace(Data dataKey,
Object update) |
Object |
DefaultRecordStore.replace(Data key,
Object update) |
boolean |
RecordStore.replace(Data dataKey,
Object expect,
Object update)
Sets the value to the given updated value
if
RecordFactory.isEquals(java.lang.Object, java.lang.Object) comparison
of current value and expected value is true . |
boolean |
DefaultRecordStore.replace(Data key,
Object expect,
Object update) |
boolean |
RecordStore.set(Data dataKey,
Object value,
long ttl)
Returns
true if key doesn't exist previously, otherwise returns false . |
boolean |
DefaultRecordStore.set(Data dataKey,
Object value,
long ttl) |
boolean |
RecordStore.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long ttl) |
boolean |
DefaultRecordStore.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long ttl) |
boolean |
RecordStore.unlock(Data key,
String caller,
long threadId,
long referenceId) |
boolean |
DefaultRecordStore.unlock(Data key,
String caller,
long threadId,
long referenceId) |
Modifier and Type | Method and Description |
---|---|
MapEntries |
RecordStore.getAll(Set<Data> keySet) |
MapEntries |
DefaultRecordStore.getAll(Set<Data> keys) |
void |
RecordStore.loadAllFromStore(List<Data> keys,
boolean replaceExistingValues)
Loads all given keys from defined map store.
|
void |
DefaultRecordStore.loadAllFromStore(List<Data> keys,
boolean replaceExistingValues) |
protected Map |
DefaultRecordStore.loadEntries(Set<Data> keys) |
Modifier and Type | Field and Description |
---|---|
protected Map<Data,VersionedValue> |
TransactionalMapProxySupport.valueMap |
Modifier and Type | Method and Description |
---|---|
Data |
TransactionalMapProxySupport.putIfAbsentInternal(Data key,
Data value) |
Data |
TransactionalMapProxySupport.putInternal(Data key,
Data value) |
Data |
TransactionalMapProxySupport.putInternal(Data key,
Data value,
long ttl,
TimeUnit timeUnit) |
Data |
TransactionalMapProxySupport.removeInternal(Data key) |
Data |
TransactionalMapProxySupport.replaceInternal(Data key,
Data value) |
Modifier and Type | Method and Description |
---|---|
boolean |
TransactionalMapProxySupport.containsKeyInternal(Data key) |
Object |
TransactionalMapProxySupport.getForUpdateInternal(Data key) |
Object |
TransactionalMapProxySupport.getInternal(Data key) |
Data |
TransactionalMapProxySupport.putIfAbsentInternal(Data key,
Data value) |
Data |
TransactionalMapProxySupport.putInternal(Data key,
Data value) |
Data |
TransactionalMapProxySupport.putInternal(Data key,
Data value,
long ttl,
TimeUnit timeUnit) |
boolean |
TransactionalMapProxySupport.removeIfSameInternal(Data key,
Object value) |
Data |
TransactionalMapProxySupport.removeInternal(Data key) |
boolean |
TransactionalMapProxySupport.replaceIfSameInternal(Data key,
Object oldValue,
Data newValue) |
Data |
TransactionalMapProxySupport.replaceInternal(Data key,
Data value) |
Constructor and Description |
---|
MapTransactionLogRecord(String name,
Data key,
int partitionId,
Operation op,
long version,
String ownerUuid) |
TxnDeleteOperation(String name,
Data dataKey,
long version) |
TxnLockAndGetOperation(String name,
Data dataKey,
long timeout,
long ttl,
String ownerUuid,
boolean shouldLoad) |
TxnPrepareBackupOperation(String name,
Data dataKey,
String lockOwner,
long lockThreadId) |
TxnPrepareOperation(int partitionId,
String name,
Data dataKey,
String ownerUuid) |
TxnRollbackBackupOperation(String name,
Data dataKey,
String lockOwner,
long lockThreadId) |
TxnRollbackOperation(int partitionId,
String name,
Data dataKey,
String ownerUuid) |
TxnSetOperation(String name,
Data dataKey,
Data value,
long version) |
TxnSetOperation(String name,
Data dataKey,
Data value,
long version,
long ttl) |
TxnUnlockBackupOperation(String name,
Data dataKey,
String ownerUuid) |
TxnUnlockOperation(String name,
Data dataKey,
long version) |
VersionedValue(Data value,
long version) |
Modifier and Type | Method and Description |
---|---|
Data |
MapReplicationRemove.getKey() |
Modifier and Type | Method and Description |
---|---|
void |
MapReplicationRemove.setKey(Data key) |
Constructor and Description |
---|
MapReplicationRemove(String mapName,
Data key,
long removeTime) |
Modifier and Type | Method and Description |
---|---|
Data |
MultiMapEventFilter.getKey() |
Modifier and Type | Method and Description |
---|---|
Map<Data,Collection<MultiMapRecord>> |
MultiMapContainer.copyCollections() |
Set<Data> |
MultiMapContainer.keySet() |
protected Set<Data> |
MultiMapProxySupport.keySetInternal() |
Set<Data> |
MultiMapService.localKeySet(String name) |
protected Set<Data> |
MultiMapProxySupport.localKeySetInternal() |
Modifier and Type | Method and Description |
---|---|
String |
MultiMapService.addListener(String name,
EventListener listener,
Data key,
boolean includeValue,
boolean local) |
boolean |
MultiMapContainer.canAcquireLock(Data dataKey,
String caller,
long threadId) |
boolean |
MultiMapContainer.containsEntry(boolean binary,
Data key,
Data value) |
protected boolean |
MultiMapProxySupport.containsInternal(Data key,
Data value) |
boolean |
MultiMapContainer.containsKey(Data key) |
boolean |
MultiMapContainer.containsValue(boolean binary,
Data value) |
protected Integer |
MultiMapProxySupport.countInternal(Data dataKey) |
void |
MultiMapContainer.delete(Data dataKey) |
boolean |
MultiMapContainer.extendLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
MultiMapContainer.forceUnlock(Data key) |
protected MultiMapResponse |
MultiMapProxySupport.getAllInternal(Data dataKey) |
String |
MultiMapContainer.getLockOwnerInfo(Data dataKey) |
boolean |
MultiMapContainer.isLocked(Data dataKey) |
boolean |
MultiMapContainer.isTransactionallyLocked(Data key) |
void |
MultiMapEventsPublisher.publishEntryEvent(String multiMapName,
EntryEventType eventType,
Data key,
Object newValue,
Object oldValue) |
void |
MultiMapService.publishEntryEvent(String multiMapName,
EntryEventType eventType,
Data key,
Object newValue,
Object oldValue) |
protected Boolean |
MultiMapProxySupport.putInternal(Data dataKey,
Data dataValue,
int index) |
Collection<MultiMapRecord> |
MultiMapContainer.remove(Data dataKey,
boolean copyOf) |
protected MultiMapResponse |
MultiMapProxySupport.removeInternal(Data dataKey) |
protected Boolean |
MultiMapProxySupport.removeInternal(Data dataKey,
Data dataValue) |
boolean |
MultiMapContainer.txnLock(Data key,
String caller,
long threadId,
long referenceId,
long ttl) |
boolean |
MultiMapContainer.unlock(Data key,
String caller,
long threadId,
long referenceId) |
Constructor and Description |
---|
MultiMapEventFilter(boolean includeValue,
Data key) |
Modifier and Type | Method and Description |
---|---|
Data |
TxnMultiMapRequest.toData(Object obj) |
Modifier and Type | Field and Description |
---|---|
protected Data |
MultiMapKeyBasedOperation.dataKey |
Modifier and Type | Method and Description |
---|---|
Data |
MultiMapOperation.toData(Object obj) |
Modifier and Type | Method and Description |
---|---|
Set<Map.Entry<Data,Data>> |
EntrySetResponse.getDataEntrySet() |
Set<Map.Entry<Data,Data>> |
EntrySetResponse.getDataEntrySet() |
Modifier and Type | Method and Description |
---|---|
void |
MultiMapOperation.publishEvent(EntryEventType eventType,
Data key,
Object newValue,
Object oldValue) |
Constructor and Description |
---|
EntrySetResponse(Map<Data,Collection<MultiMapRecord>> map,
NodeEngine nodeEngine) |
Modifier and Type | Method and Description |
---|---|
protected Collection<MultiMapRecord> |
TransactionalMultiMapProxySupport.getInternal(Data key) |
protected boolean |
TransactionalMultiMapProxySupport.putInternal(Data key,
Data value) |
protected Collection<MultiMapRecord> |
TransactionalMultiMapProxySupport.removeAllInternal(Data key) |
protected boolean |
TransactionalMultiMapProxySupport.removeInternal(Data key,
Data value) |
protected int |
TransactionalMultiMapProxySupport.valueCountInternal(Data key) |
Constructor and Description |
---|
MultiMapTransactionLogRecord(int partitionId,
Data key,
String name,
long ttl,
long threadId) |
TxnCommitBackupOperation(String name,
Data dataKey,
List<Operation> opList,
String caller,
long threadId) |
TxnCommitOperation(int partitionId,
String name,
Data dataKey,
long threadId,
List<Operation> opList) |
TxnGenerateRecordIdOperation(String name,
Data dataKey) |
TxnLockAndGetOperation(String name,
Data dataKey,
long timeout,
long ttl,
long threadId) |
TxnPrepareBackupOperation(String name,
Data dataKey,
String caller,
long threadId) |
TxnPrepareOperation(int partitionId,
String name,
Data dataKey,
long ttl,
long threadId) |
TxnPutBackupOperation(String name,
Data dataKey,
long recordId,
Data value) |
TxnPutOperation(String name,
Data dataKey,
Data value,
long recordId) |
TxnRemoveAllBackupOperation(String name,
Data dataKey,
Collection<Long> recordIds) |
TxnRemoveAllOperation(String name,
Data dataKey,
Collection<MultiMapRecord> records) |
TxnRemoveBackupOperation(String name,
Data dataKey,
long recordId,
Data value) |
TxnRemoveOperation(String name,
Data dataKey,
long recordId,
Data value) |
TxnRollbackBackupOperation(String name,
Data dataKey,
String caller,
long threadId) |
TxnRollbackOperation(int partitionId,
String name,
Data dataKey,
long threadId) |
Modifier and Type | Class and Description |
---|---|
class |
Packet
A Packet is a piece of data send over the line.
|
Modifier and Type | Method and Description |
---|---|
Data |
ObjectDataInput.readData() |
Data |
NodeIOService.toData(Object obj) |
Data |
IOService.toData(Object obj) |
Modifier and Type | Method and Description |
---|---|
static long |
IOUtil.extractOperationCallId(Data data,
SerializationService serializationService)
This method has a direct dependency on how objects are serialized in
DataSerializer ! If the stream
format is ever changed this extraction method needs to be changed too! |
Object |
NodeIOService.toObject(Data data) |
Object |
IOService.toObject(Data data) |
void |
ObjectDataOutput.writeData(Data data) |
Modifier and Type | Method and Description |
---|---|
int |
InternalPartitionService.getPartitionId(Data key)
Returns the partition id for a Data key.
|
Modifier and Type | Method and Description |
---|---|
int |
InternalPartitionServiceImpl.getPartitionId(Data key) |
Modifier and Type | Method and Description |
---|---|
Data |
QueryEntry.getKeyData() |
abstract Data |
QueryableEntry.getKeyData() |
Data |
CachedQueryEntry.getKeyData() |
Data |
QueryEntry.getValueData() |
abstract Data |
QueryableEntry.getValueData() |
Data |
CachedQueryEntry.getValueData() |
Modifier and Type | Method and Description |
---|---|
ConcurrentMap<Data,QueryableEntry> |
UnsortedIndexStore.getRecordMap(Comparable value) |
ConcurrentMap<Data,QueryableEntry> |
IndexStore.getRecordMap(Comparable indexValue) |
ConcurrentMap<Data,QueryableEntry> |
SortedIndexStore.getRecordMap(Comparable value) |
Modifier and Type | Method and Description |
---|---|
void |
QueryEntry.init(SerializationService serializationService,
Data key,
Object value,
Extractors extractors)
It may be useful to use this
init method in some cases that same instance of this class can be used
instead of creating a new one for every iteration when scanning large data sets, for example: |
void |
CachedQueryEntry.init(SerializationService serializationService,
Data key,
Object value,
Extractors extractors) |
void |
Index.removeEntryIndex(Data key,
Object value) |
void |
IndexImpl.removeEntryIndex(Data key,
Object value) |
void |
Indexes.removeEntryIndex(Data key,
Object value) |
void |
IndexStore.removeIndex(Object oldValue,
Data indexKey) |
void |
BaseIndexStore.removeIndex(Object oldValue,
Data indexKey) |
Modifier and Type | Method and Description |
---|---|
void |
FastMultiResultSet.addResultSet(ConcurrentMap<Data,QueryableEntry> resultSet) |
void |
MultiResultSet.addResultSet(ConcurrentMap<Data,QueryableEntry> resultSet)
TODO
|
void |
DuplicateDetectingMultiResult.addResultSet(ConcurrentMap<Data,QueryableEntry> resultSet) |
Constructor and Description |
---|
CachedQueryEntry(SerializationService serializationService,
Data key,
Object value,
Extractors extractors) |
QueryEntry(SerializationService serializationService,
Data key,
Object value,
Extractors extractors) |
Constructor and Description |
---|
SingleResultSet(ConcurrentMap<Data,QueryableEntry> records) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicatedMapEventPublishingService.fireEntryListenerEvent(Data key,
Data oldValue,
Data value,
EntryEventType eventType,
String name,
Address caller) |
void |
ReplicatedMapEventPublishingService.fireEntryListenerEvent(Data key,
Data oldValue,
Data value,
String name,
Address caller) |
Modifier and Type | Method and Description |
---|---|
Data |
ReplicatedMapPortableEntryEvent.getKey() |
Data |
ReplicatedMapPortableEntryEvent.getOldValue() |
Data |
ReplicatedMapPortableEntryEvent.getValue() |
Modifier and Type | Method and Description |
---|---|
List<Map.Entry<Data,Data>> |
ReplicatedMapEntries.getEntries() |
List<Map.Entry<Data,Data>> |
ReplicatedMapEntries.getEntries() |
List<Data> |
ReplicatedMapKeys.getKeys() |
Collection<Data> |
ReplicatedMapValueCollection.getValues() |
Modifier and Type | Method and Description |
---|---|
void |
ReplicatedMapEntries.add(Data key,
Data value) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicatedMapEntries.add(Map.Entry<Data,Data> entry) |
void |
ReplicatedMapEntries.add(Map.Entry<Data,Data> entry) |
Constructor and Description |
---|
ClientReplicatedMapAddEntryListenerRequest(String mapName,
Predicate predicate,
Data key) |
ClientReplicatedMapContainsKeyRequest(String mapName,
Data key) |
ClientReplicatedMapContainsValueRequest(String mapName,
Data value,
int partitionId) |
ClientReplicatedMapGetRequest(String mapName,
Data key) |
ClientReplicatedMapPutTtlRequest(String name,
Data key,
Data value,
long ttlMillis) |
ClientReplicatedMapRemoveRequest(String name,
Data key) |
Constructor and Description |
---|
ReplicatedMapEntries(List<Map.Entry<Data,Data>> entries) |
ReplicatedMapEntries(List<Map.Entry<Data,Data>> entries) |
ReplicatedMapKeys(List<Data> keys) |
ReplicatedMapValueCollection(Collection<Data> values) |
Modifier and Type | Field and Description |
---|---|
protected Data |
AbstractReplicatedMapOperation.key |
protected Data |
AbstractReplicatedMapOperation.value |
Constructor and Description |
---|
ContainsKeyOperation(String name,
Data key) |
ContainsValueOperation(String name,
Data value) |
GetOperation(String name,
Data key) |
PutOperation(String name,
Data key,
Data value) |
PutOperation(String name,
Data key,
Data value,
long ttl) |
RemoveOperation(String name,
Data key) |
ReplicateUpdateOperation(String name,
Data dataKey,
Data dataValue,
long ttl,
VersionResponsePair response,
boolean isRemove,
Address origin) |
ReplicateUpdateToCallerOperation(String name,
long callId,
Data dataKey,
Data dataValue,
VersionResponsePair response,
long ttl,
boolean isRemove) |
Modifier and Type | Field and Description |
---|---|
protected Data |
ReplicatedEntryEventFilter.key |
Modifier and Type | Method and Description |
---|---|
Data |
RecordMigrationInfo.getKey() |
Data |
RecordMigrationInfo.getValue() |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractReplicatedRecordStore.sendReplicationOperation(boolean isRemove,
String name,
Data key,
Data value,
long ttl,
VersionResponsePair response) |
void |
RecordMigrationInfo.setKey(Data key) |
void |
RecordMigrationInfo.setValue(Data value) |
Constructor and Description |
---|
RecordMigrationInfo(Data key,
Data value,
long ttl) |
ReplicatedEntryEventFilter(Data key) |
ReplicatedQueryEventFilter(Data key,
Predicate predicate) |
Modifier and Type | Method and Description |
---|---|
Data[] |
ReadResultSetImpl.getDataItems() |
Data |
RingbufferContainer.read(long sequence) |
Modifier and Type | Method and Description |
---|---|
long |
RingbufferContainer.add(Data item) |
long |
RingbufferContainer.addAll(Data[] items) |
Modifier and Type | Method and Description |
---|---|
List<Data> |
PortableReadResultSet.getDataItems() |
Constructor and Description |
---|
AddAllRequest(String name,
Data[] items,
OverflowPolicy overflowPolicy) |
AddRequest(String name,
Data item,
OverflowPolicy overflowPolicy) |
ReadManyRequest(String name,
long startSequence,
int minCount,
int maxCount,
Data filter) |
Constructor and Description |
---|
PortableReadResultSet(int readCount,
List<Data> items) |
Modifier and Type | Method and Description |
---|---|
Data |
ReadOneOperation.getResponse() |
Constructor and Description |
---|
AddAllBackupOperation(String name,
Data[] items) |
AddAllOperation(String name,
Data[] items,
OverflowPolicy overflowPolicy) |
AddBackupOperation(String name,
Data item) |
AddOperation(String name,
Data item,
OverflowPolicy overflowPolicy) |
Modifier and Type | Method and Description |
---|---|
protected Data |
AbstractDistributedObject.getNameAsPartitionAwareData() |
Data |
NodeEngine.toData(Object object)
Serializes an object to a
Data . |
Modifier and Type | Method and Description |
---|---|
protected int |
AbstractDistributedObject.getPartitionId(Data key) |
Modifier and Type | Method and Description |
---|---|
Data |
PortableItemEvent.getItem() |
Data |
PortableEntryEvent.getKey() |
Data |
PortableEntryEvent.getMergingValue() |
Data |
PortableEntryEvent.getOldValue() |
Data |
PortableEntryEvent.getValue() |
Data |
NodeEngineImpl.toData(Object object) |
Modifier and Type | Method and Description |
---|---|
Collection<Data> |
PortableCollection.getCollection() |
List<Data> |
SerializableList.getCollection() |
Iterator<Data> |
SerializableList.iterator() |
Constructor and Description |
---|
BinaryOperationFactory(Data operationData) |
PortableEntryEvent(Data key,
Data value,
Data oldValue,
Data mergingValue,
EntryEventType eventType,
String uuid) |
PortableItemEvent(Data item,
ItemEventType eventType,
String uuid) |
Constructor and Description |
---|
PortableCollection(Collection<Data> collection) |
SerializableList(List<Data> collection) |
Constructor and Description |
---|
Backup(Data backupOpData,
Address originalCaller,
long[] replicaVersions,
boolean sync) |
Modifier and Type | Field and Description |
---|---|
Data |
TopicEvent.data |
Modifier and Type | Method and Description |
---|---|
Data |
DataAwareMessage.getMessageData() |
Modifier and Type | Method and Description |
---|---|
void |
TopicProxySupport.publishInternal(Data message) |
Constructor and Description |
---|
DataAwareMessage(String topicName,
Data messageData,
long publishTime,
Member publishingMember,
SerializationService serializationService) |
PublishOperation(String name,
Data message) |
TopicEvent(String name,
Data data,
Address publisherAddress) |
Modifier and Type | Method and Description |
---|---|
Data |
PortableMessage.getMessage() |
Constructor and Description |
---|
PortableMessage(Data message,
long publishTime,
String uuid) |
PublishRequest(String name,
Data message) |
Modifier and Type | Method and Description |
---|---|
Data |
ReliableTopicMessage.getPayload() |
Constructor and Description |
---|
ReliableTopicMessage(Data payload,
Address publisherAddress) |
Constructor and Description |
---|
ClearRemoteTransactionRequest(Data xidData) |
FinalizeXATransactionRequest(Data xidData,
boolean isCommit) |
Constructor and Description |
---|
ClearRemoteTransactionBackupOperation(Data xidData) |
ClearRemoteTransactionOperation(Data xidData) |
FinalizeRemoteTransactionBackupOperation(Data xidData) |
FinalizeRemoteTransactionOperation(Data xidData,
boolean isCommit) |
Modifier and Type | Method and Description |
---|---|
int |
SampleableConcurrentHashMap.fetch(int tableIndex,
int size,
List<Data> keys)
Fetches keys from given
tableIndex as size
and puts them into keys list. |
Modifier and Type | Method and Description |
---|---|
Map<String,Data> |
SessionState.getAttributes() |
Modifier and Type | Method and Description |
---|---|
void |
SessionState.setAttribute(String key,
Data value) |
Modifier and Type | Method and Description |
---|---|
void |
SessionState.set(Map<String,Data> attributes) |
Modifier and Type | Method and Description |
---|---|
Data |
GetAttributeEntryProcessor.process(Map.Entry<String,SessionState> entry) |
Modifier and Type | Method and Description |
---|---|
Map<String,Data> |
SessionUpdateEntryProcessor.getAttributes() |
Constructor and Description |
---|
SessionUpdateEntryProcessor(String key,
Data value) |
Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.