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.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.record |
Hazelcast JSR-107 aka JCache implementation
Internal record store
|
com.hazelcast.client |
Contains classes/interfaces related to Client
|
com.hazelcast.client.cache.impl |
Hazelcast JSR-107 aka JCache implementation client side
|
com.hazelcast.client.connection.nio |
Contains classes related to New IO for com.hazelcast.client.connection
|
com.hazelcast.client.impl |
Contains most of the client side HazelcastInstance implementation functionality.
|
com.hazelcast.client.impl.client |
This contains the Requests and other DTO's exchanged between client/server
|
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 |
This package contains classes related to Collections (IList,ISet etc..)
|
com.hazelcast.collection.client |
This package contains client functionality for Collections in Hazelcast.
|
com.hazelcast.collection.common |
This package contains common classes related to all collections
|
com.hazelcast.collection.list |
This package contains IList functionality for Hazelcast.
|
com.hazelcast.collection.set |
This package contains ISet functionality for Hazelcast.
|
com.hazelcast.collection.txn |
This package contains the Transaction behavior for the Collections.
|
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.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.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.operation |
Package for map operations.
|
com.hazelcast.map.impl.record |
Contains record specific classes.
|
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.nio.serialization |
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
|
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.queue.impl |
This package contains the IQueue functionality.
The IQueue is the distributed version of the BlockingQueue . |
com.hazelcast.queue.impl.client |
This package contains client requests for the IQueue.
|
com.hazelcast.queue.impl.operations |
This package contains the IQueue operations
|
com.hazelcast.queue.impl.proxy |
This package contains the IQueue proxies.
|
com.hazelcast.queue.impl.tx |
This package contains the Transaction behavior for the IQueue.
|
com.hazelcast.spi |
Provides interfaces/classes for Hazelcast SPI.
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.storage |
This package contains storage functionality for Hazelcast.
|
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.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.
|
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 |
CacheEventData.getDataKey()
Gets cache entry key as
Data . |
Data |
CacheEventDataImpl.getDataKey() |
Data |
CacheEventData.getDataOldValue()
Gets the old value of entry as
Data , if available. |
Data |
CacheEventDataImpl.getDataOldValue() |
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) |
protected Data |
AbstractCacheRecordStore.toEventData(Object obj) |
protected Data |
CacheRecordStore.toHeapData(Object obj) |
protected abstract Data |
AbstractCacheRecordStore.toHeapData(Object obj) |
protected <T> Data |
CacheRecordStore.valueToData(T value) |
protected abstract <T> Data |
AbstractCacheRecordStore.valueToData(T value) |
Modifier and Type | Method and Description |
---|---|
protected EvictionPolicyEvaluator<Data,R> |
AbstractCacheRecordStore.creatEvictionPolicyEvaluator(CacheEvictionConfig cacheEvictionConfig) |
protected EvictionStrategy<Data,R,CRM> |
AbstractCacheRecordStore.creatEvictionStrategy(CacheEvictionConfig cacheEvictionConfig) |
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 |
---|---|
boolean |
ICacheRecordStore.contains(Data key)
Determines if this store contains an entry for the specified key.
|
boolean |
AbstractCacheRecordStore.contains(Data key) |
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) |
Operation |
CacheOperationProvider.createContainsKeyOperation(Data key) |
Operation |
DefaultOperationProvider.createContainsKeyOperation(Data key) |
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) |
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) |
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) |
R |
AbstractCacheRecordStore.createRecordWithExpiry(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId) |
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 CacheRecord |
CacheRecordStore.dataToRecord(Data data) |
protected abstract R |
AbstractCacheRecordStore.dataToRecord(Data data) |
protected <T> T |
CacheRecordStore.dataToValue(Data data) |
protected abstract <T> T |
AbstractCacheRecordStore.dataToValue(Data data) |
protected void |
AbstractCacheRecordStore.deleteCacheEntry(Data key) |
protected boolean |
AbstractCacheRecordStore.deleteRecord(Data key,
int completionId) |
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 caller,
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 caller,
int completionId) |
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 caller,
int completionId) |
protected 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) |
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 |
AbstractCacheRecordStore.onDeleteRecord(Data key,
R record,
Data dataValue,
boolean deleted) |
protected void |
AbstractCacheRecordStore.onDeleteRecordError(Data key,
R record,
Data dataValue,
boolean deleted,
Throwable error) |
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 |
AbstractCacheRecordStore.onPut(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
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 caller,
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 caller,
boolean disableWriteThrough,
R record,
boolean isExpired,
boolean isSaveSucceed) |
protected void |
AbstractCacheRecordStore.onPutIfAbsentError(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
boolean disableWriteThrough,
R record,
Throwable error) |
protected void |
AbstractCacheRecordStore.onRemove(Data key,
Object value,
String caller,
boolean getValue,
R record,
boolean removed) |
protected void |
AbstractCacheRecordStore.onRemoveError(Data key,
Object value,
String caller,
boolean getValue,
R record,
boolean removed,
Throwable error) |
protected void |
AbstractCacheRecordStore.onReplace(Data key,
Object oldValue,
Object newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
boolean getValue,
R record,
boolean isExpired,
boolean replaced) |
protected void |
AbstractCacheRecordStore.onReplaceError(Data key,
Object oldValue,
Object newValue,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
boolean getValue,
R record,
boolean isExpired,
boolean replaced,
Throwable error) |
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) |
boolean |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long now) |
R |
AbstractCacheRecordStore.processExpiredEntry(Data key,
R record,
long expiryTime,
long now) |
protected void |
AbstractCacheRecordStore.publishEvent(CacheEventType eventType,
Data dataKey,
Data dataOldValue,
Data dataValue,
boolean isOldValueAvailable,
int completionId) |
void |
AbstractCacheService.publishEvent(String cacheName,
CacheEventType eventType,
Data dataKey,
Data dataValue,
Data dataOldValue,
boolean isOldValueAvailable,
int orderKey,
int completionId) |
void |
ICacheService.publishEvent(String cacheName,
CacheEventType eventType,
Data dataKey,
Data dataValue,
Data dataOldValue,
boolean isOldValueAvailable,
int orderKey,
int completionId) |
protected Object |
AbstractCacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
boolean getValue,
boolean disableWriteThrough,
int completionId) |
protected Object |
AbstractCacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
boolean getValue,
int completionId) |
void |
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.
|
void |
AbstractCacheRecordStore.put(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
int completionId) |
protected boolean |
AbstractCacheRecordStore.putIfAbsent(Data key,
Object value,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
String caller,
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 caller,
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 caller,
int completionId) |
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 caller,
int completionId) |
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 caller,
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 caller,
int completionId) |
void |
ICacheRecordStore.setRecord(Data key,
CacheRecord record)
Associates the specified record with the specified key.
|
void |
AbstractCacheRecordStore.setRecord(Data key,
CacheRecord record) |
protected R |
AbstractCacheRecordStore.updateRecord(Data key,
R record,
Object value,
int completionId) |
boolean |
AbstractCacheRecordStore.updateRecordWithExpiry(Data key,
Object value,
R record,
javax.cache.expiry.ExpiryPolicy expiryPolicy,
long now,
boolean disableWriteThrough,
int completionId) |
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) |
OperationFactory |
CacheOperationProvider.createRemoveAllOperationFactory(Set<Data> keySet,
Integer completionId) |
OperationFactory |
DefaultOperationProvider.createRemoveAllOperationFactory(Set<Data> keySet,
Integer completionId) |
protected void |
AbstractCacheRecordStore.deleteAllCacheEntry(Set<Data> keys) |
MapEntrySet |
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. |
MapEntrySet |
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) |
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 | Field and Description |
---|---|
protected Data |
CacheRemoveRequest.currentValue |
protected Data |
CacheReplaceRequest.currentValue |
protected Data |
CachePutRequest.key |
protected Data |
CacheRemoveRequest.key |
protected Data |
CacheReplaceRequest.key |
protected Data |
CachePutIfAbsentRequest.key |
protected Data |
CacheGetAndRemoveRequest.key |
protected Data |
CacheGetRequest.key |
protected Data |
CacheContainsKeyRequest.key |
protected Data |
CacheGetAndReplaceRequest.key |
protected Data |
CacheEntryProcessorRequest.key |
protected Data |
CachePutRequest.value |
protected Data |
CacheReplaceRequest.value |
protected Data |
CachePutIfAbsentRequest.value |
protected Data |
CacheGetAndReplaceRequest.value |
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) |
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) |
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) |
CachePutBackupOperation(String name,
Data key,
CacheRecord cacheRecord) |
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) |
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) |
CachePutAllBackupOperation(String name,
Map<Data,CacheRecord> cacheRecords) |
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) |
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) |
void |
CacheDataRecord.setValue(Data value) |
Constructor and Description |
---|
CacheDataRecord(Data value,
long creationTime,
long expiryTime) |
CacheRecordHashMap.EvictableSamplingEntry(Data key,
CacheRecord value) |
Modifier and Type | Method and Description |
---|---|
void |
ClientEndpoint.sendEvent(Data key,
Object event,
int callId) |
Modifier and Type | Method and Description |
---|---|
protected Data |
ClientClusterWideIterator.toData(Object obj) |
Modifier and Type | Method and Description |
---|---|
Data |
ClientConnection.read() |
Modifier and Type | Method and Description |
---|---|
void |
ClientConnection.write(Data data) |
Modifier and Type | Method and Description |
---|---|
void |
ClientEndpointImpl.sendEvent(Data key,
Object event,
int callId) |
void |
ClientEngineImpl.sendResponse(ClientEndpoint endpoint,
Data key,
Object response,
int callId,
boolean isError,
boolean isEvent) |
Modifier and Type | Method and Description |
---|---|
Data |
ClientResponse.getResponse() |
Constructor and Description |
---|
ClientResponse(Data response,
int callId,
boolean isError) |
Modifier and Type | Method and Description |
---|---|
Data |
ClientSemaphoreProxy.getKey() |
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 |
---|---|
void |
ClientCallFuture.andThenInternal(ExecutionCallback<Data> callback) |
Modifier and Type | Field and Description |
---|---|
protected Data |
CollectionAddOperation.value |
protected Data |
CollectionItem.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 |
---|---|
Data |
CollectionItem.getValue() |
Modifier and Type | Method and Description |
---|---|
protected Map<Long,Data> |
CollectionContainer.addAll(List<Data> valueList) |
protected Map<Long,Data> |
CollectionContainer.clear() |
protected Map<Long,Data> |
CollectionContainer.compareAndRemove(boolean retain,
Set<Data> valueSet) |
protected Collection<Data> |
CollectionContainer.getAll() |
Modifier and Type | Method and Description |
---|---|
protected long |
CollectionContainer.add(Data value) |
protected void |
CollectionContainer.addBackup(long itemId,
Data value) |
void |
CollectionContainer.commitAdd(long itemId,
Data value) |
void |
CollectionContainer.commitAddBackup(long itemId,
Data value) |
protected void |
CollectionOperation.publishEvent(ItemEventType eventType,
Data data) |
protected 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 |
---|---|
protected Map<Long,Data> |
CollectionContainer.addAll(List<Data> valueList) |
protected void |
CollectionContainer.addAllBackup(Map<Long,Data> valueMap) |
protected Map<Long,Data> |
CollectionContainer.compareAndRemove(boolean retain,
Set<Data> valueSet) |
protected boolean |
CollectionContainer.contains(Set<Data> valueSet) |
Constructor and Description |
---|
CollectionAddBackupOperation(String name,
long itemId,
Data value) |
CollectionAddOperation(String name,
Data value) |
CollectionEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
CollectionItem(long itemId,
Data value) |
CollectionRemoveOperation(String name,
Data value) |
TxCollectionItem(long itemId,
Data value,
String transactionId,
boolean removeOperation) |
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 | 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) |
ListAddRequest(String name,
Data value,
int index) |
ListIndexOfRequest(String name,
Data value,
boolean last) |
ListSetRequest(String name,
int index,
Data value) |
TxnCollectionRequest(String name,
Data value) |
TxnListAddRequest(String name,
Data value) |
TxnListRemoveRequest(String name,
Data value) |
TxnSetAddRequest(String name,
Data value) |
TxnSetRemoveRequest(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) |
ListAddAllRequest(String name,
List<Data> valueList,
int index) |
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 | Method and Description |
---|---|
protected Map<Long,Data> |
ListContainer.addAll(int index,
List<Data> valueList) |
protected List<Data> |
ListContainer.sub(int from,
int to) |
Modifier and Type | Method and Description |
---|---|
protected CollectionItem |
ListContainer.add(int index,
Data value) |
protected int |
ListContainer.indexOf(boolean last,
Data value) |
protected CollectionItem |
ListContainer.set(int index,
long itemId,
Data value) |
protected void |
ListContainer.setBackup(long oldItemId,
long itemId,
Data value) |
Modifier and Type | Method and Description |
---|---|
protected Map<Long,Data> |
ListContainer.addAll(int index,
List<Data> valueList) |
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 | Method and Description |
---|---|
protected Map<Long,Data> |
SetContainer.addAll(List<Data> valueList) |
Modifier and Type | Method and Description |
---|---|
protected Map<Long,Data> |
SetContainer.addAll(List<Data> valueList) |
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) |
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 |
ReferenceWrapper.get() |
Data |
ReferenceWrapper.getAndSet(Data value) |
Modifier and Type | Method and Description |
---|---|
boolean |
ReferenceWrapper.compareAndSet(Data expect,
Data value) |
boolean |
ReferenceWrapper.contains(Data expected) |
Data |
ReferenceWrapper.getAndSet(Data value) |
void |
ReferenceWrapper.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) |
void |
LockServiceImpl.cancelEviction(ObjectNamespace namespace,
Data key) |
boolean |
LockStoreProxy.extendLeaseTime(Data key,
String caller,
long threadId,
long ttl) |
boolean |
LockStore.extendLeaseTime(Data key,
String caller,
long threadId,
long ttl) |
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) |
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 |
LockStoreImpl.lock(Data key,
String caller,
long threadId) |
boolean |
LockStoreProxy.lock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
LockStore.lock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
LockStoreImpl.lock(Data key,
String caller,
long threadId,
long leaseTime) |
void |
LockProxySupport.lock(NodeEngine nodeEngine,
Data key) |
void |
LockProxySupport.lock(NodeEngine nodeEngine,
Data key,
long ttl) |
void |
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
Data key) |
void |
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
Data key,
long ttl) |
AwaitOperation |
LockStoreImpl.pollExpiredAwaitOp(Data key) |
boolean |
LockStoreImpl.removeAwait(Data key,
String conditionId,
String caller,
long threadId) |
void |
LockServiceImpl.scheduleEviction(ObjectNamespace namespace,
Data key,
int version,
long delay) |
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 |
LockStoreProxy.txnLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
LockStore.txnLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
LockStoreImpl.txnLock(Data key,
String caller,
long threadId,
long leaseTime) |
boolean |
LockStoreProxy.unlock(Data key,
String caller,
long threadId) |
boolean |
LockStore.unlock(Data key,
String caller,
long threadId) |
boolean |
LockStoreImpl.unlock(Data key,
String caller,
long threadId) |
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) |
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) |
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,
long threadId) |
LockBackupOperation(ObjectNamespace namespace,
Data key,
long threadId,
String originalCallerUuid) |
LockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long timeout) |
LockOperation(ObjectNamespace namespace,
Data key,
long threadId,
long ttl,
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 | Field and Description |
---|---|
protected Data |
EntryEventData.dataKey |
protected Data |
EntryEventData.dataNewValue |
protected Data |
EntryEventData.dataOldValue |
Modifier and Type | Method and Description |
---|---|
Data |
EntryEventData.getDataKey() |
Data |
EntryEventData.getDataNewValue() |
Data |
EntryEventData.getDataOldValue() |
Data |
EntryEventFilter.getKey() |
Data |
NearCache.CacheRecord.getKey() |
Data |
DataAwareEntryEvent.getKeyData() |
Data |
DataAwareEntryEvent.getNewValueData() |
Data |
DataAwareEntryEvent.getOldValueData() |
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 |
---|---|
Set<Map.Entry<Data,Data>> |
RecordStore.entrySetData() |
Set<Map.Entry<Data,Data>> |
RecordStore.entrySetData() |
Set<Map.Entry<Data,Data>> |
DefaultRecordStore.entrySetData() |
Set<Map.Entry<Data,Data>> |
DefaultRecordStore.entrySetData() |
Set<Map.Entry<Data,Data>> |
MapEntrySet.getEntrySet() |
Set<Map.Entry<Data,Data>> |
MapEntrySet.getEntrySet() |
Set<Data> |
MapKeySet.getKeySet() |
MapDataStore<Data,Object> |
RecordStore.getMapDataStore() |
MapDataStore<Data,Object> |
DefaultRecordStore.getMapDataStore() |
Map.Entry<Data,Object> |
RecordStore.getMapEntry(Data dataKey,
long now) |
Map.Entry<Data,Object> |
DefaultRecordStore.getMapEntry(Data key,
long now) |
Map<Data,NearCache.CacheRecord> |
NearCache.getReadonlyMap() |
Map<Data,Record> |
RecordStore.getRecordMap()
Returns records map.
|
Map<Data,Record> |
DefaultRecordStore.getRecordMap() |
Collection<Data> |
MapValueCollection.getValues() |
Set<Data> |
RecordStore.keySet() |
Set<Data> |
DefaultRecordStore.keySet() |
Collection<Data> |
RecordStore.valuesData() |
Collection<Data> |
DefaultRecordStore.valuesData() |
Modifier and Type | Method and Description |
---|---|
void |
MapEntrySet.add(Data key,
Data value) |
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) |
Record |
MapContainer.createRecord(Data key,
Object value,
long ttlMillis,
long now) |
boolean |
RecordStore.delete(Data dataKey) |
boolean |
DefaultRecordStore.delete(Data key) |
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 |
NearCache.get(Data key) |
Object |
RecordStore.get(Data dataKey,
boolean backup)
Gets record from
RecordStore . |
Object |
DefaultRecordStore.get(Data key,
boolean backup) |
Object |
NearCacheProvider.getFromNearCache(String mapName,
Data key) |
String |
RecordStore.getLockOwnerInfo(Data key) |
String |
DefaultRecordStore.getLockOwnerInfo(Data key) |
Map.Entry<Data,Object> |
RecordStore.getMapEntry(Data dataKey,
long now) |
Map.Entry<Data,Object> |
DefaultRecordStore.getMapEntry(Data key,
long now) |
Record |
RecordStore.getRecord(Data key) |
Record |
DefaultRecordStore.getRecord(Data key) |
Record |
RecordStore.getRecordOrNull(Data key)
Returns live record or null if record is already expired.
|
Record |
DefaultRecordStore.getRecordOrNull(Data key) |
void |
NearCache.invalidate(Data key) |
void |
NearCacheProvider.invalidateAllNearCaches(String mapName,
Data key) |
void |
NearCacheProvider.invalidateNearCache(String mapName,
Data key) |
boolean |
RecordStore.isLocked(Data key) |
boolean |
DefaultRecordStore.isLocked(Data dataKey) |
boolean |
MapServiceContext.isOwnedKey(Data key)
Check if key belongs on partitions of the this node
|
boolean |
DefaultMapServiceContext.isOwnedKey(Data key) |
boolean |
RecordStore.isTransactionallyLocked(Data key) |
boolean |
DefaultRecordStore.isTransactionallyLocked(Data key) |
boolean |
RecordStore.merge(Data dataKey,
EntryView mergingEntryView,
MapMergePolicy mergePolicy) |
boolean |
DefaultRecordStore.merge(Data key,
EntryView mergingEntry,
MapMergePolicy mergePolicy) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
boolean synthetic,
Data dataKey,
Data dataOldValue,
Data dataValue) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Data dataOldValue,
Data dataValue) |
void |
MapEventPublisher.publishWanReplicationRemove(String mapName,
Data key,
long removeTime) |
Object |
NearCache.put(Data key,
Data data) |
Object |
RecordStore.put(Data dataKey,
Object dataValue,
long ttl) |
Object |
DefaultRecordStore.put(Data key,
Object value,
long ttl) |
Record |
RecordStore.putBackup(Data key,
Object value) |
Record |
DefaultRecordStore.putBackup(Data key,
Object value) |
Record |
RecordStore.putBackup(Data key,
Object value,
long ttl) |
Record |
DefaultRecordStore.putBackup(Data key,
Object value,
long ttl) |
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.putIfAbsent(Data dataKey,
Object value,
long ttl) |
Object |
DefaultRecordStore.putIfAbsent(Data key,
Object value,
long ttl) |
Object |
NearCacheProvider.putNearCache(String mapName,
Data key,
Data value) |
void |
RecordStore.putRecord(Data key,
Record 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) |
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) |
boolean |
DefaultRecordStore.set(Data key,
Object value,
long ttl) |
boolean |
RecordStore.tryPut(Data dataKey,
Object value,
long ttl) |
boolean |
DefaultRecordStore.tryPut(Data key,
Object value,
long ttl) |
boolean |
RecordStore.txnLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
DefaultRecordStore.txnLock(Data key,
String caller,
long threadId,
long ttl) |
boolean |
RecordStore.unlock(Data key,
String caller,
long threadId) |
boolean |
DefaultRecordStore.unlock(Data key,
String caller,
long threadId) |
Modifier and Type | Method and Description |
---|---|
void |
MapEntrySet.add(Map.Entry<Data,Data> entry) |
void |
MapEntrySet.add(Map.Entry<Data,Data> entry) |
MapEntrySet |
RecordStore.getAll(Set<Data> keySet) |
MapEntrySet |
DefaultRecordStore.getAll(Set<Data> keys) |
void |
NearCache.invalidate(Collection<Data> keys) |
void |
NearCacheProvider.invalidateAllNearCaches(String mapName,
Set<Data> keys) |
void |
NearCacheProvider.invalidateNearCache(String mapName,
Collection<Data> keys) |
void |
RecordStore.loadAllFromStore(List<Data> keys,
boolean replaceExistingValues)
Loads all keys from defined map store.
|
void |
DefaultRecordStore.loadAllFromStore(List<Data> keys,
boolean replaceExistingValues) |
void |
RecordStore.put(Map.Entry<Data,Object> entry) |
void |
DefaultRecordStore.put(Map.Entry<Data,Object> entry) |
Constructor and Description |
---|
DataAwareEntryEvent(Member from,
int eventType,
String source,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
SerializationService serializationService) |
EntryEventData(String source,
String mapName,
Address caller,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
int eventType) |
EntryEventFilter(boolean includeValue,
Data key) |
MapRecordKey(String mapName,
Data key) |
QueryEventFilter(boolean includeValue,
Data key,
Predicate predicate) |
Constructor and Description |
---|
MapEntrySet(Set<Map.Entry<Data,Data>> entrySet) |
MapEntrySet(Set<Map.Entry<Data,Data>> entrySet) |
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 |
---|
MapExecuteOnKeysRequest(String name,
EntryProcessor processor,
Set<Data> keys) |
MapGetAllRequest(String name,
Set<Data> keys) |
MapLoadGivenKeysRequest(String name,
List<Data> keys,
boolean replaceExistingValues) |
Modifier and Type | Method and Description |
---|---|
void |
EvictionOperator.fireEvent(Data key,
Object value,
String mapName,
MapServiceContext mapServiceContext) |
Modifier and Type | Method and Description |
---|---|
protected Data |
AbstractMapDataStore.toData(Object obj) |
Modifier and Type | Method and Description |
---|---|
Map<Data,Object> |
MapStoreContext.getInitialKeys() |
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,
long now,
boolean backup)
GOTCHA: When
WriteBehindStore.writeCoalescing is true, you may see more than one write operations
to map store, e.g. |
Object |
WriteBehindStore.load(Data key) |
boolean |
WriteBehindStore.loadable(Data key,
long lastUpdateTime,
long now)
* 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 |
---|---|
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,
long now,
boolean backup) |
Object |
WriteThroughStore.load(Data key) |
boolean |
WriteThroughStore.loadable(Data key,
long lastUpdateTime,
long now) |
void |
WriteThroughStore.remove(Data key,
long time) |
void |
WriteThroughStore.removeBackup(Data key,
long time) |
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 |
---|---|
protected void |
PutAllOperation.invalidateNearCaches(Set<Data> keys) |
Modifier and Type | Method and Description |
---|---|
Data |
Record.getKey() |
Data |
RecordReplicationInfo.getKey() |
Data |
RecordReplicationInfo.getValue() |
Modifier and Type | Method and Description |
---|---|
Record<Data> |
NativeRecordFactory.newRecord(Data key,
Object value) |
Record<Data> |
DataRecordFactory.newRecord(Data key,
Object value) |
Modifier and Type | Method and Description |
---|---|
Record<Data> |
NativeRecordFactory.newRecord(Data key,
Object value) |
Record<Object> |
ObjectRecordFactory.newRecord(Data key,
Object value) |
Record<Data> |
DataRecordFactory.newRecord(Data key,
Object value) |
Record<T> |
RecordFactory.newRecord(Data key,
Object value) |
Modifier and Type | Method and Description |
---|---|
void |
NativeRecordFactory.setValue(Record<Data> record,
Object value) |
void |
DataRecordFactory.setValue(Record<Data> record,
Object value) |
Constructor and Description |
---|
RecordReplicationInfo(Data key,
Data value,
RecordInfo recordInfo) |
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 |
---|---|
protected List<Map.Entry<Data,Data>> |
TransactionalMapProxySupport.getEntries() |
protected List<Map.Entry<Data,Data>> |
TransactionalMapProxySupport.getEntries() |
protected Set<Data> |
TransactionalMapProxySupport.keySetInternal() |
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 |
---|
MapTransactionLog(String name,
Data key,
Operation op,
long version,
String ownerUuid) |
TxnDeleteOperation(String name,
Data dataKey,
long version) |
TxnLockAndGetOperation(String name,
Data dataKey,
long timeout,
long ttl,
String ownerUuid) |
TxnPrepareBackupOperation(String name,
Data dataKey,
String lockOwner,
long lockThreadId) |
TxnPrepareOperation(String name,
Data dataKey,
String ownerUuid) |
TxnRollbackBackupOperation(String name,
Data dataKey,
String lockOwner,
long lockThreadId) |
TxnRollbackOperation(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) |
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 value) |
void |
MultiMapService.publishEntryEvent(String multiMapName,
EntryEventType eventType,
Data key,
Object value) |
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 ttl) |
boolean |
MultiMapContainer.unlock(Data key,
String caller,
long threadId) |
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 value) |
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 |
---|
MultiMapTransactionLog(Data key,
String name,
long ttl,
long threadId) |
TxnCommitBackupOperation(String name,
Data dataKey,
List<Operation> opList,
String caller,
long threadId) |
TxnCommitOperation(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(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(String name,
Data dataKey,
long threadId) |
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) |
Constructor and Description |
---|
Packet(Data value,
int partitionId,
PortableContext context) |
Packet(Data value,
PortableContext context) |
Modifier and Type | Field and Description |
---|---|
protected Data |
DataAdapter.data |
Modifier and Type | Method and Description |
---|---|
<B extends Data> |
SerializationService.readData(ObjectDataInput in) |
<B extends Data> |
SerializationService.toData(Object obj) |
<B extends Data> |
SerializationService.toData(Object obj,
PartitioningStrategy strategy) |
Modifier and Type | Method and Description |
---|---|
Data |
DataAdapter.getData() |
Data |
ObjectDataInputStream.readData() |
Data |
SerializationServiceImpl.readData(ObjectDataInput in) |
Data |
SerializationServiceImpl.toData(Object obj) |
Data |
SerializationServiceImpl.toData(Object obj,
PartitioningStrategy strategy) |
Modifier and Type | Method and Description |
---|---|
BufferObjectDataInput |
InputOutputFactory.createInput(Data data,
SerializationService service) |
BufferObjectDataInput |
SerializationServiceImpl.createObjectDataInput(Data data) |
BufferObjectDataInput |
SerializationService.createObjectDataInput(Data data) |
PortableReader |
SerializationServiceImpl.createPortableReader(Data data) |
PortableReader |
SerializationService.createPortableReader(Data data) |
void |
SerializationServiceImpl.disposeData(Data data) |
void |
SerializationService.disposeData(Data data) |
ClassDefinition[] |
PortableContext.getClassDefinitions(Data data) |
static int |
DataAdapter.getDataSize(Data data,
PortableContext context) |
boolean |
PortableContext.hasClassDefinition(Data data) |
ClassDefinition |
PortableContext.lookupClassDefinition(Data data) |
void |
DataAdapter.setData(Data data) |
void |
ObjectDataOutputStream.writeData(Data data) |
void |
SerializationServiceImpl.writeData(ObjectDataOutput out,
Data data) |
void |
SerializationService.writeData(ObjectDataOutput out,
Data data) |
protected void |
SerializationServiceImpl.writeDataInternal(ObjectDataOutput out,
Data data) |
protected void |
SerializationServiceImpl.writePortableHeader(ObjectDataOutput out,
Data data) |
Constructor and Description |
---|
ClassDefinitionSerializer(Data data,
PortableContext context) |
DataAdapter(Data data,
PortableContext context) |
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.getIndexKey() |
Data |
QueryResultEntry.getIndexKey() |
Data |
QueryResultEntryImpl.getIndexKey() |
Data |
QueryEntry.getKeyData() |
Data |
QueryResultEntry.getKeyData() |
Data |
QueryResultEntryImpl.getKeyData() |
Data |
QueryEntry.getValueData() |
Data |
QueryResultEntry.getValueData() |
Data |
QueryResultEntryImpl.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) |
ConcurrentMap<Data,Comparable> |
IndexImpl.getRecordValues() |
Modifier and Type | Method and Description |
---|---|
void |
IndexService.removeEntryIndex(Data indexKey) |
void |
Index.removeEntryIndex(Data indexKey) |
void |
IndexImpl.removeEntryIndex(Data indexKey) |
void |
UnsortedIndexStore.removeIndex(Comparable oldValue,
Data indexKey) |
void |
IndexStore.removeIndex(Comparable oldValue,
Data indexKey) |
void |
SortedIndexStore.removeIndex(Comparable oldValue,
Data indexKey) |
Modifier and Type | Method and Description |
---|---|
void |
MultiResultSet.addResultSet(ConcurrentMap<Data,QueryableEntry> resultSet) |
Constructor and Description |
---|
QueryEntry(SerializationService serializationService,
Data indexKey,
Object key,
Object value) |
QueryResultEntryImpl(Data keyData,
Data indexKey,
Data valueData) |
Constructor and Description |
---|
SingleResultSet(ConcurrentMap<Data,QueryableEntry> records) |
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) |
TxQueueItem(QueueContainer container,
long itemId,
Data data) |
Constructor and Description |
---|
OfferRequest(String name,
Data data) |
OfferRequest(String name,
long timeoutMillis,
Data data) |
RemoveRequest(String name,
Data data) |
TxnOfferRequest(String name,
long timeout,
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) |
Constructor and Description |
---|
QueueIterator(Iterator<Data> iterator,
SerializationService serializationService,
boolean binary) |
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 |
---|
TxnOfferBackupOperation(String name,
long itemId,
Data data) |
TxnOfferOperation(String name,
long itemId,
Data data) |
Modifier and Type | Method and Description |
---|---|
protected Data |
AbstractDistributedObject.getNameAsPartitionAwareData() |
Data |
NodeEngine.toData(Object object) |
Modifier and Type | Method and Description |
---|---|
Data |
PortableItemEvent.getItem() |
Data |
PortableEntryEvent.getKey() |
Data |
PortableEntryEvent.getOldValue() |
Data |
PortableEntryEvent.getValue() |
Data |
NodeEngineImpl.toData(Object object) |
Modifier and Type | Method and Description |
---|---|
Collection<Data> |
SerializableCollection.getCollection() |
Collection<Data> |
PortableCollection.getCollection() |
Iterator<Data> |
SerializableCollection.iterator() |
Constructor and Description |
---|
BinaryOperationFactory(Data operationData) |
PortableEntryEvent(Data key,
Data value,
Data oldValue,
EntryEventType eventType,
String uuid) |
PortableItemEvent(Data item,
ItemEventType eventType,
String uuid) |
SerializableCollection(Data... dataArray) |
Constructor and Description |
---|
PortableCollection(Collection<Data> collection) |
SerializableCollection(Collection<Data> collection) |
Modifier and Type | Method and Description |
---|---|
Data |
Storage.get(int hash,
REF ref) |
Modifier and Type | Method and Description |
---|---|
REF |
Storage.put(int hash,
Data data) |
Modifier and Type | Field and Description |
---|---|
Data |
TopicEvent.data |
Modifier and Type | Method and Description |
---|---|
Data |
DataAwareMessage.getMessageData() |
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 |
---|---|
int |
SampleableConcurrentHashMap.fetch(int tableIndex,
int size,
List<Data> keys)
Fetches keys from given
tableIndex as size
and puts them into keys list. |
Copyright © 2014 Hazelcast, Inc.. All Rights Reserved.