| Package | Description | 
|---|---|
| com.hazelcast.client.cache.impl | 
 
     Hazelcast JSR-107 aka JCache implementation client side 
 | 
| com.hazelcast.client.impl.protocol.task | 
 Client tasks associated with requests. 
 | 
| com.hazelcast.client.impl.protocol.task.atomiclong | 
 Client protocol tasks implementations for AtomicLong 
 | 
| com.hazelcast.client.impl.protocol.task.atomicreference | 
 Client protocol tasks implementations for AtomicReference 
 | 
| com.hazelcast.client.impl.protocol.task.cache | 
 Client protocol tasks implementations for JCache 
 | 
| com.hazelcast.client.impl.protocol.task.cardinality | |
| com.hazelcast.client.impl.protocol.task.condition | 
 Client protocol tasks implementations for Condition 
 | 
| com.hazelcast.client.impl.protocol.task.countdownlatch | 
 Client protocol tasks implementations for CountDownLatch 
 | 
| com.hazelcast.client.impl.protocol.task.crdt.pncounter | |
| com.hazelcast.client.impl.protocol.task.dynamicconfig | |
| com.hazelcast.client.impl.protocol.task.executorservice | 
 Client protocol tasks implementations for ExecutorService 
 | 
| com.hazelcast.client.impl.protocol.task.executorservice.durable | |
| com.hazelcast.client.impl.protocol.task.list | 
 Client protocol tasks implementations for List 
 | 
| com.hazelcast.client.impl.protocol.task.lock | 
 Client protocol tasks implementations for ILock 
 | 
| com.hazelcast.client.impl.protocol.task.map | 
 Client protocol tasks implementations for map 
 | 
| com.hazelcast.client.impl.protocol.task.mapreduce | 
 Client protocol tasks implementations for map reduce 
 | 
| com.hazelcast.client.impl.protocol.task.multimap | 
 Client protocol tasks implementations for multi map 
 | 
| com.hazelcast.client.impl.protocol.task.queue | 
 Client protocol tasks implementations for Queue 
 | 
| com.hazelcast.client.impl.protocol.task.replicatedmap | 
 Client protocol tasks implementations for ReplicatedMap 
 | 
| com.hazelcast.client.impl.protocol.task.ringbuffer | 
 Client protocol tasks implementations for Ringbuffer 
 | 
| com.hazelcast.client.impl.protocol.task.scheduledexecutor | |
| com.hazelcast.client.impl.protocol.task.semaphore | 
 Client protocol tasks implementations for Semaphore 
 | 
| com.hazelcast.client.impl.protocol.task.set | 
 Client protocol tasks implementations for set 
 | 
| com.hazelcast.client.impl.protocol.task.topic | 
 Client protocol tasks implementations for Topic 
 | 
| com.hazelcast.client.impl.protocol.task.transaction | 
 Client protocol tasks implementations for Transaction related 
 | 
| com.hazelcast.client.proxy | 
 This package contains client side proxy implementations of the different Hazelcast data structures
 and operation types 
 | 
| com.hazelcast.client.spi.impl | 
 Provides util classes for the Hazelcast client SPI. 
 | 
| com.hazelcast.client.util | 
 This package contains some utility classes and the base implementations of the
 loadbalancer implementations 
 | 
| com.hazelcast.core | 
 Provides core API interfaces/classes. 
 | 
| com.hazelcast.executor.impl | 
 This package contains IExecutorService functionality for Hazelcast. 
The IExecutorService extends the ExecutorService and provides all kinds
 of additional methods related to distributed systems. | 
| com.hazelcast.internal.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.map.impl.proxy | 
 Contains map proxy implementation and support classes. 
 | 
| com.hazelcast.spi | 
 Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services. 
 | 
| com.hazelcast.spi.impl | 
 Contains implementations for Hazelcast SPI. 
 | 
| com.hazelcast.spi.impl.operationservice | 
 Contains the  
InternalOperationService API. | 
| com.hazelcast.spi.impl.operationservice.impl | 
 Contains the code for the  
InternalOperationService implementation. | 
| com.hazelcast.topic.impl.reliable | |
| com.hazelcast.transaction.impl | 
 Provides implementation for Hazelcast transaction support. 
 | 
| com.hazelcast.transaction.impl.xa | 
 Provides implementation for Hazelcast XA transaction support. 
 | 
| com.hazelcast.util.executor | 
 This package contains classes related to Util.Executor  
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected InternalCompletableFuture<V> | 
NearCachedClientCacheProxy.getAsyncInternal(Object key,
                javax.cache.expiry.ExpiryPolicy expiryPolicy,
                ExecutionCallback<V> callback)  | 
protected <T> void | 
NearCachedClientCacheProxy.onGetAndRemoveAsyncInternal(K key,
                           Data keyData,
                           ClientDelegatingFuture<T> delegatingFuture,
                           ExecutionCallback<T> callback)  | 
protected void | 
NearCachedClientCacheProxy.onPutIfAbsentAsyncInternal(K key,
                          V value,
                          Data keyData,
                          Data valueData,
                          ClientDelegatingFuture<Boolean> delegatingFuture,
                          ExecutionCallback<Boolean> callback)  | 
protected void | 
NearCachedClientCacheProxy.onRemoveAsyncInternal(Object key,
                     Data keyData,
                     ClientDelegatingFuture future,
                     ExecutionCallback callback)  | 
protected <T> void | 
NearCachedClientCacheProxy.onReplaceAndGetAsync(K key,
                    V value,
                    Data keyData,
                    Data valueData,
                    ClientDelegatingFuture<T> delegatingFuture,
                    ExecutionCallback<T> callback)  | 
protected <T> void | 
NearCachedClientCacheProxy.onReplaceInternalAsync(K key,
                      V value,
                      Data keyData,
                      Data valueData,
                      ClientDelegatingFuture<T> delegatingFuture,
                      ExecutionCallback<T> callback)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractAddressMessageTask<P>
AbstractAddressMessageTask 
 | 
class  | 
AbstractAllPartitionsMessageTask<P>  | 
class  | 
AbstractInvocationMessageTask<P>  | 
class  | 
AbstractMultiPartitionMessageTask<P>  | 
class  | 
AbstractPartitionMessageTask<P>
AbstractPartitionMessageTask 
 | 
class  | 
AbstractStableClusterMessageTask<P>  | 
class  | 
AuthenticationBaseMessageTask<P>
Base authentication task 
 | 
class  | 
AuthenticationCustomCredentialsMessageTask
Custom Authentication with custom credential impl 
 | 
class  | 
AuthenticationMessageTask
Default Authentication with username password handling task 
 | 
class  | 
CreateProxyMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AtomicLongAddAndGetMessageTask  | 
class  | 
AtomicLongAlterAndGetMessageTask  | 
class  | 
AtomicLongAlterMessageTask  | 
class  | 
AtomicLongApplyMessageTask  | 
class  | 
AtomicLongCompareAndSetMessageTask  | 
class  | 
AtomicLongDecrementAndGetMessageTask  | 
class  | 
AtomicLongGetAndAddMessageTask  | 
class  | 
AtomicLongGetAndAlterMessageTask  | 
class  | 
AtomicLongGetAndIncrementMessageTask  | 
class  | 
AtomicLongGetAndSetMessageTask  | 
class  | 
AtomicLongGetMessageTask  | 
class  | 
AtomicLongIncrementAndGetMessageTask  | 
class  | 
AtomicLongSetMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AtomicReferenceAlterAndGetMessageTask  | 
class  | 
AtomicReferenceAlterMessageTask  | 
class  | 
AtomicReferenceApplyMessageTask  | 
class  | 
AtomicReferenceClearMessageTask  | 
class  | 
AtomicReferenceCompareAndSetMessageTask  | 
class  | 
AtomicReferenceContainsMessageTask  | 
class  | 
AtomicReferenceGetAndAlterMessageTask  | 
class  | 
AtomicReferenceGetAndSetMessageTask  | 
class  | 
AtomicReferenceGetMessageTask  | 
class  | 
AtomicReferenceIsNullMessageTask  | 
class  | 
AtomicReferenceSetAndGetMessageTask  | 
class  | 
AtomicReferenceSetMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractCacheMessageTask<P>
Abstract Cache request to handle InMemoryFormat which needed for operation provider 
 | 
class  | 
CacheAssignAndGetUuidsMessageTask  | 
class  | 
CacheClearMessageTask
This client request  specifically calls  
CacheClearOperationFactory on the server side. | 
class  | 
CacheContainsKeyMessageTask
This client request  specifically calls  
CacheContainsKeyOperation on the server side. | 
class  | 
CacheCreateConfigMessageTask
Creates the given CacheConfig on all members of the cluster. 
 | 
class  | 
CacheEntryProcessorMessageTask
This client request  specifically calls  
CacheEntryProcessorOperation on the server side. | 
class  | 
CacheEventJournalReadTask<K,V,T>
Reads from the cache event journal in batches. 
 | 
class  | 
CacheEventJournalSubscribeTask
Performs the initial subscription to the cache event journal. 
 | 
class  | 
CacheFetchNearCacheInvalidationMetadataTask  | 
class  | 
CacheGetAllMessageTask
This client request  specifically calls  
CacheGetAllOperationFactory on the server side. | 
class  | 
CacheGetAndRemoveMessageTask
This client request  specifically calls  
CacheGetAndRemoveOperation on the server side. | 
class  | 
CacheGetAndReplaceMessageTask
This client request specifically calls  
CacheGetAndReplaceOperation on the server side. | 
class  | 
CacheGetConfigMessageTask
This client request specifically calls  
CacheGetConfigOperation on the server side. | 
class  | 
CacheGetMessageTask
This client request  specifically calls  
CacheGetOperation on the server side. | 
class  | 
CacheIterateEntriesMessageTask
This client request specifically calls  
CacheEntryIteratorOperation on the server side. | 
class  | 
CacheIterateMessageTask
This client request  specifically calls  
CacheKeyIteratorOperation on the server side. | 
class  | 
CacheListenerRegistrationMessageTask
This client request  specifically calls  
CacheListenerRegistrationOperation on the server side. | 
class  | 
CacheLoadAllMessageTask
This client request  specifically calls  
CacheLoadAllOperationFactory on the server side. | 
class  | 
CacheManagementConfigMessageTask
This client request  specifically calls  
CacheManagementConfigOperation on the server side. | 
class  | 
CachePutAllMessageTask
This client request specifically calls  
CachePutAllOperation on the server side. | 
class  | 
CachePutIfAbsentMessageTask
This client request  specifically calls  
CachePutIfAbsentOperation on the server side. | 
class  | 
CachePutMessageTask
This client request  specifically calls  
CachePutOperation on the server side. | 
class  | 
CacheRemoveAllKeysMessageTask
This client request  specifically calls  
CacheRemoveAllOperationFactory on the server side. | 
class  | 
CacheRemoveAllMessageTask
This client request  specifically calls  
CacheRemoveAllOperationFactory on the server side. | 
class  | 
CacheRemoveMessageTask
This client request  specifically calls  
CacheRemoveOperation on the server side. | 
class  | 
CacheReplaceMessageTask
This client request specifically calls  
CachePutOperation on the server side. | 
class  | 
CacheSetExpiryPolicyMessageTask  | 
class  | 
CacheSizeMessageTask
This client request specifically calls  
CacheSizeOperationFactory on the server side. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CardinalityEstimatorAddMessageTask  | 
class  | 
CardinalityEstimatorEstimateMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ConditionAwaitMessageTask  | 
class  | 
ConditionBeforeAwaitMessageTask  | 
class  | 
ConditionSignalAllMessageTask  | 
class  | 
ConditionSignalMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CountDownLatchAwaitMessageTask  | 
class  | 
CountDownLatchCountDownMessageTask  | 
class  | 
CountDownLatchGetCountMessageTask  | 
class  | 
CountDownLatchTrySetCountMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
PNCounterAddMessageTask
Task responsible for processing client messages for updating the
  
PNCounter state. | 
class  | 
PNCounterGetMessageTask
Task responsible for processing client messages for retrieving the
 current  
PNCounter state. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractAddConfigMessageTask<P>
Base implementation for dynamic add***Config methods. 
 | 
class  | 
AddCacheConfigMessageTask  | 
class  | 
AddCardinalityEstimatorConfigMessageTask  | 
class  | 
AddDurableExecutorConfigMessageTask  | 
class  | 
AddEventJournalConfigMessageTask  | 
class  | 
AddExecutorConfigMessageTask  | 
class  | 
AddFlakeIdGeneratorConfigMessageTask  | 
class  | 
AddListConfigMessageTask  | 
class  | 
AddLockConfigMessageTask  | 
class  | 
AddMapConfigMessageTask  | 
class  | 
AddMerkleTreeConfigMessageTask
Member side task for adding a merkle tree configuration. 
 | 
class  | 
AddMultiMapConfigMessageTask  | 
class  | 
AddQueueConfigMessageTask  | 
class  | 
AddReliableTopicConfigMessageTask  | 
class  | 
AddReplicatedMapConfigMessageTask  | 
class  | 
AddRingbufferConfigMessageTask  | 
class  | 
AddScheduledExecutorConfigMessageTask  | 
class  | 
AddSemaphoreConfigMessageTask  | 
class  | 
AddSetConfigMessageTask  | 
class  | 
AddTopicConfigMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ExecutorServiceSubmitToAddressMessageTask  | 
class  | 
ExecutorServiceSubmitToPartitionMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DurableExecutorDisposeResultMessageTask  | 
class  | 
DurableExecutorRetrieveAndDisposeResultMessageTask  | 
class  | 
DurableExecutorRetrieveResultMessageTask  | 
class  | 
DurableExecutorSubmitToPartitionMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ListAddAllMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_ADDALL | 
class  | 
ListAddAllWithIndexMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_ADDALLWITHINDEX | 
class  | 
ListAddMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_ADD | 
class  | 
ListAddWithIndexMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_ADDWITHINDEX | 
class  | 
ListClearMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_CLEAR | 
class  | 
ListCompareAndRemoveAllMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_COMPAREANDREMOVEALL | 
class  | 
ListCompareAndRetainAllMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_COMPAREANDRETAINALL | 
class  | 
ListContainsAllMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_CONTAINSALL | 
class  | 
ListContainsMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_CONTAINS | 
class  | 
ListGetAllMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_GETALL | 
class  | 
ListGetMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_GET | 
class  | 
ListIndexOfMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_INDEXOF | 
class  | 
ListIsEmptyMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_ADDLISTENER | 
class  | 
ListIteratorMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_ITERATOR | 
class  | 
ListLastIndexOfMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_LASTINDEXOF | 
class  | 
ListListIteratorMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_LISTITERATOR | 
class  | 
ListRemoveMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_REMOVE | 
class  | 
ListRemoveWithIndexMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_REMOVEWITHINDEX | 
class  | 
ListSetMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_SET | 
class  | 
ListSizeMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_SIZE | 
class  | 
ListSubMessageTask
Client Protocol Task for handling messages with type ID:
  
ListMessageType.LIST_SUB | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
LockForceUnlockMessageTask  | 
class  | 
LockGetLockCountMessageTask  | 
class  | 
LockGetRemainingLeaseTimeMessageTask  | 
class  | 
LockIsLockedByCurrentThreadMessageTask  | 
class  | 
LockIsLockedMessageTask  | 
class  | 
LockLockMessageTask  | 
class  | 
LockTryLockMessageTask  | 
class  | 
LockUnlockMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractMapReduceTask<Parameters>  | 
class  | 
MapReduceForCustomMessageTask  | 
class  | 
MapReduceForListMessageTask  | 
class  | 
MapReduceForMapMessageTask  | 
class  | 
MapReduceForMultiMapMessageTask  | 
class  | 
MapReduceForSetMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
MultiMapClearMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_CLEAR | 
class  | 
MultiMapContainsEntryMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_CONTAINSENTRY | 
class  | 
MultiMapContainsKeyMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_CONTAINSKEY | 
class  | 
MultiMapContainsValueMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_CONTAINSVALUE | 
class  | 
MultiMapDeleteMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_DELETE | 
class  | 
MultiMapEntrySetMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_ENTRYSET | 
class  | 
MultiMapForceUnlockMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_FORCEUNLOCK | 
class  | 
MultiMapGetMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_GET | 
class  | 
MultiMapIsLockedMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_ISLOCKED | 
class  | 
MultiMapKeySetMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_KEYSET | 
class  | 
MultiMapLockMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_LOCK | 
class  | 
MultiMapPutMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_PUT | 
class  | 
MultiMapRemoveEntryMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_REMOVEENTRY | 
class  | 
MultiMapRemoveMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_REMOVE | 
class  | 
MultiMapSizeMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_SIZE | 
class  | 
MultiMapTryLockMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_TRYLOCK | 
class  | 
MultiMapUnlockMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_UNLOCK | 
class  | 
MultiMapValueCountMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_VALUECOUNT | 
class  | 
MultiMapValuesMessageTask
Client Protocol Task for handling messages with type ID:
  
MultiMapMessageType.MULTIMAP_VALUES | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
QueueAddAllMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_ADDLISTENER | 
class  | 
QueueClearMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_CLEAR | 
class  | 
QueueCompareAndRemoveAllMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_COMPAREANDREMOVEALL | 
class  | 
QueueCompareAndRetainAllMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_COMPAREANDRETAINALL | 
class  | 
QueueContainsAllMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_CONTAINSALL | 
class  | 
QueueContainsMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_CONTAINS | 
class  | 
QueueDrainMaxSizeMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_DRAINTOMAXSIZE | 
class  | 
QueueDrainMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_DRAINTO | 
class  | 
QueueIsEmptyMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_ISEMPTY | 
class  | 
QueueIteratorMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_ITERATOR | 
class  | 
QueueOfferMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_OFFER | 
class  | 
QueuePeekMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_PEEK | 
class  | 
QueuePollMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_POLL | 
class  | 
QueuePutMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_PUT | 
class  | 
QueueRemainingCapacityMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_REMAININGCAPACITY | 
class  | 
QueueRemoveMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_REMOVE | 
class  | 
QueueSizeMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_SIZE | 
class  | 
QueueTakeMessageTask
Client Protocol Task for handling messages with type ID:
  
QueueMessageType.QUEUE_TAKE | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ReplicatedMapClearMessageTask  | 
class  | 
ReplicatedMapContainsKeyMessageTask  | 
class  | 
ReplicatedMapContainsValueMessageTask  | 
class  | 
ReplicatedMapEntrySetMessageTask  | 
class  | 
ReplicatedMapGetMessageTask  | 
class  | 
ReplicatedMapIsEmptyMessageTask  | 
class  | 
ReplicatedMapKeySetMessageTask  | 
class  | 
ReplicatedMapPutAllMessageTask  | 
class  | 
ReplicatedMapPutMessageTask  | 
class  | 
ReplicatedMapRemoveMessageTask  | 
class  | 
ReplicatedMapSizeMessageTask  | 
class  | 
ReplicatedMapValuesMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
RingbufferAddAllMessageTask
Client Protocol Task for handling messages with type ID:
  
RingbufferMessageType.RINGBUFFER_ADDALL | 
class  | 
RingbufferAddMessageTask
Client Protocol Task for handling messages with type ID:
  
RingbufferMessageType.RINGBUFFER_ADD | 
class  | 
RingbufferCapacityMessageTask  | 
class  | 
RingbufferHeadSequenceMessageTask  | 
class  | 
RingbufferReadManyMessageTask
Client Protocol Task for handling messages with type ID:
  
RingbufferMessageType.RINGBUFFER_READMANY | 
class  | 
RingbufferReadOneMessageTask
Client Protocol Task for handling messages with type ID:
  
RingbufferMessageType.RINGBUFFER_READONE | 
class  | 
RingbufferRemainingCapacityMessageTask  | 
class  | 
RingbufferSizeMessageTask  | 
class  | 
RingbufferTailSequenceMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SemaphoreAcquireMessageTask  | 
class  | 
SemaphoreAvailablePermitsMessageTasks  | 
class  | 
SemaphoreDrainPermitsMessageTask  | 
class  | 
SemaphoreIncreasePermitsMessageTask  | 
class  | 
SemaphoreInitMessageTask  | 
class  | 
SemaphoreReducePermitsMessageTask  | 
class  | 
SemaphoreReleaseMessageTask  | 
class  | 
SemaphoreTryAcquireMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SetAddAllMessageTask
SetAddAllMessageTask 
 | 
class  | 
SetAddMessageTask
SetAddMessageTask 
 | 
class  | 
SetClearMessageTask
SetClearMessageTask 
 | 
class  | 
SetCompareAndRemoveAllMessageTask
SetCompareAndRemoveAllMessageTask 
 | 
class  | 
SetCompareAndRetainAllMessageTask
SetCompareAndRetainAllMessageTask 
 | 
class  | 
SetContainsAllMessageTask
SetContainsAllMessageTask 
 | 
class  | 
SetContainsMessageTask
SetContainsMessageTask 
 | 
class  | 
SetGetAllMessageTask
SetGetAllMessageTask 
 | 
class  | 
SetIsEmptyMessageTask
SetIsEmptyMessageTask 
 | 
class  | 
SetRemoveMessageTask
SetRemoveMessageTask 
 | 
class  | 
SetSizeMessageTask
SetSizeMessageTask 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TopicPublishMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
XAFinalizeTransactionMessageTask  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ClientReliableMessageRunner<E>
Client implementation of   
MessageRunner | 
| Modifier and Type | Method and Description | 
|---|---|
<T> void | 
ClientExecutorServiceProxy.submit(Callable<T> task,
      ExecutionCallback<T> callback)  | 
<T> void | 
ClientExecutorServiceProxy.submit(Callable<T> task,
      MemberSelector memberSelector,
      ExecutionCallback<T> callback)  | 
<T> void | 
ClientExecutorServiceProxy.submit(Runnable command,
      ExecutionCallback<T> callback)  | 
void | 
ClientExecutorServiceProxy.submit(Runnable task,
      MemberSelector memberSelector,
      ExecutionCallback callback)  | 
void | 
ClientMapProxy.submitToKey(K key,
           EntryProcessor entryProcessor,
           ExecutionCallback callback)  | 
void | 
NearCachedClientMapProxy.submitToKeyInternal(Object key,
                   EntryProcessor entryProcessor,
                   ExecutionCallback callback)  | 
void | 
ClientMapProxy.submitToKeyInternal(Object key,
                   EntryProcessor entryProcessor,
                   ExecutionCallback callback)  | 
<T> void | 
ClientExecutorServiceProxy.submitToKeyOwner(Callable<T> task,
                Object key,
                ExecutionCallback<T> callback)  | 
void | 
ClientExecutorServiceProxy.submitToKeyOwner(Runnable command,
                Object key,
                ExecutionCallback callback)  | 
<T> void | 
ClientExecutorServiceProxy.submitToMember(Callable<T> task,
              Member member,
              ExecutionCallback<T> callback)  | 
void | 
ClientExecutorServiceProxy.submitToMember(Runnable command,
              Member member,
              ExecutionCallback callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ClientInvocationFuture.andThen(ExecutionCallback<ClientMessage> callback)  | 
void | 
ClientInvocationFuture.andThen(ExecutionCallback<ClientMessage> callback,
       Executor executor)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ClientDelegatingFuture.andThen(ExecutionCallback<V> callback)  | 
void | 
ClientDelegatingFuture.andThen(ExecutionCallback<V> callback,
       Executor executor)  | 
<T> void | 
ClientDelegatingFuture.andThenInternal(ExecutionCallback<T> callback,
               boolean shouldDeserializeData)
Uses internal executor to execute callbacks instead of  
ClientDelegatingFuture.userExecutor. | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ICompletableFuture.andThen(ExecutionCallback<V> callback)
Registers a callback that will run after this future is completed. 
 | 
void | 
ICompletableFuture.andThen(ExecutionCallback<V> callback,
       Executor executor)
Registers a callback that will run with the provided executor after this
 future is completed. 
 | 
<T> void | 
IExecutorService.submit(Callable<T> task,
      ExecutionCallback<T> callback)
Submits a task to a random member. 
 | 
<T> void | 
IExecutorService.submit(Callable<T> task,
      MemberSelector memberSelector,
      ExecutionCallback<T> callback)
Submits task to a randomly selected member. 
 | 
<T> void | 
IExecutorService.submit(Runnable task,
      ExecutionCallback<T> callback)
Submits a task to a random member. 
 | 
<T> void | 
IExecutorService.submit(Runnable task,
      MemberSelector memberSelector,
      ExecutionCallback<T> callback)
Submits a task to randomly selected members. 
 | 
void | 
IMap.submitToKey(K key,
           EntryProcessor entryProcessor,
           ExecutionCallback callback)
Applies the user defined  
EntryProcessor to the entry mapped by the key with
 specified ExecutionCallback to listen event status and returns immediately. | 
<T> void | 
IExecutorService.submitToKeyOwner(Callable<T> task,
                Object key,
                ExecutionCallback<T> callback)
Submits task to the owner of the specified key. 
 | 
<T> void | 
IExecutorService.submitToKeyOwner(Runnable task,
                Object key,
                ExecutionCallback<T> callback)
Submits a task to the owner of the specified key. 
 | 
<T> void | 
IExecutorService.submitToMember(Callable<T> task,
              Member member,
              ExecutionCallback<T> callback)
Submits a task to the specified member. 
 | 
<T> void | 
IExecutorService.submitToMember(Runnable task,
              Member member,
              ExecutionCallback<T> callback)
Submits a task to the specified member. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<T> void | 
ExecutorServiceProxy.submit(Callable<T> task,
      ExecutionCallback<T> callback)  | 
<T> void | 
ExecutorServiceProxy.submit(Callable<T> task,
      MemberSelector memberSelector,
      ExecutionCallback<T> callback)  | 
void | 
ExecutorServiceProxy.submit(Runnable task,
      ExecutionCallback callback)  | 
void | 
ExecutorServiceProxy.submit(Runnable task,
      MemberSelector memberSelector,
      ExecutionCallback callback)  | 
<T> void | 
ExecutorServiceProxy.submitToKeyOwner(Callable<T> task,
                Object key,
                ExecutionCallback<T> callback)  | 
void | 
ExecutorServiceProxy.submitToKeyOwner(Runnable task,
                Object key,
                ExecutionCallback callback)  | 
<T> void | 
ExecutorServiceProxy.submitToMember(Callable<T> task,
              Member member,
              ExecutionCallback<T> callback)  | 
void | 
ExecutorServiceProxy.submitToMember(Runnable task,
              Member member,
              ExecutionCallback callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SimpleCompletedFuture.andThen(ExecutionCallback<E> callback)  | 
void | 
SimpleCompletedFuture.andThen(ExecutionCallback<E> callback,
       Executor executor)  | 
| Modifier and Type | Method and Description | 
|---|---|
InternalCompletableFuture<Object> | 
NearCachedMapProxyImpl.executeOnKeyInternal(Object key,
                    EntryProcessor entryProcessor,
                    ExecutionCallback<Object> callback)  | 
ICompletableFuture<Map<K,Object>> | 
NearCachedMapProxyImpl.executeOnKeysInternalAsync(Set<K> keys,
                          Set<Data> dataKeys,
                          EntryProcessor entryProcessor,
                          ExecutionCallback<Map<K,Object>> callback)  | 
void | 
MapProxyImpl.submitToKey(K key,
           EntryProcessor entryProcessor,
           ExecutionCallback callback)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected ExecutionCallback<Object> | 
InvocationBuilder.executionCallback  | 
| Modifier and Type | Method and Description | 
|---|---|
ExecutionCallback<Object> | 
InvocationBuilder.getExecutionCallback()
Gets the ExecutionCallback. 
 | 
protected ExecutionCallback | 
InvocationBuilder.getTargetExecutionCallback()  | 
| Modifier and Type | Method and Description | 
|---|---|
<T> ICompletableFuture<Map<Integer,T>> | 
OperationService.invokeOnAllPartitionsAsync(String serviceName,
                          OperationFactory operationFactory,
                          ExecutionCallback<Map<Integer,T>> callback)
Invokes a set of operations on selected set of all partitions in an async way. 
 | 
<T> ICompletableFuture<Map<Integer,T>> | 
OperationService.invokeOnPartitionsAsync(String serviceName,
                       OperationFactory operationFactory,
                       Collection<Integer> partitions,
                       ExecutionCallback<Map<Integer,T>> callback)
Invokes a set of operations on selected set of partitions in an async way. 
 | 
InvocationBuilder | 
InvocationBuilder.setExecutionCallback(ExecutionCallback<Object> executionCallback)
Sets the ExecutionCallback. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SimpleExecutionCallback<E>
A ExecutionCallback implementation that simplifies the implementation of the ExecutionCallback by only
 needing to implement a single method. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
AbstractCompletableFuture.andThen(ExecutionCallback<V> callback)  | 
void | 
AbstractInvocationFuture.andThen(ExecutionCallback<V> callback)  | 
void | 
AbstractCompletableFuture.andThen(ExecutionCallback<V> callback,
       Executor executor)  | 
void | 
AbstractInvocationFuture.andThen(ExecutionCallback<V> callback,
       Executor executor)  | 
| Modifier and Type | Method and Description | 
|---|---|
<V> void | 
InternalOperationService.asyncInvokeOnPartition(String serviceName,
                      Operation op,
                      int partitionId,
                      ExecutionCallback<V> callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
<V> void | 
OperationServiceImpl.asyncInvokeOnPartition(String serviceName,
                      Operation op,
                      int partitionId,
                      ExecutionCallback<V> callback)  | 
<T> ICompletableFuture<Map<Integer,T>> | 
OperationServiceImpl.invokeOnAllPartitionsAsync(String serviceName,
                          OperationFactory operationFactory,
                          ExecutionCallback<Map<Integer,T>> callback)  | 
<T> ICompletableFuture<Map<Integer,T>> | 
OperationServiceImpl.invokeOnPartitionsAsync(String serviceName,
                       OperationFactory operationFactory,
                       Collection<Integer> partitions,
                       ExecutionCallback<Map<Integer,T>> callback)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
MessageRunner<E>
An  
ExecutionCallback that will try to read an
 item from the ringbuffer or blocks if no item is available. | 
class  | 
ReliableMessageRunner<E>  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TransactionLog.commitAsync(NodeEngine nodeEngine,
           ExecutionCallback callback)  | 
void | 
TransactionLog.rollbackAsync(NodeEngine nodeEngine,
             ExecutionCallback callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
XATransaction.commitAsync(ExecutionCallback callback)  | 
void | 
XATransaction.rollbackAsync(ExecutionCallback callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
DelegatingFuture.andThen(ExecutionCallback<V> callback)  | 
void | 
CompletedFuture.andThen(ExecutionCallback<V> callback)  | 
void | 
DelegatingFuture.andThen(ExecutionCallback<V> callback,
       Executor executor)  | 
void | 
CompletedFuture.andThen(ExecutionCallback<V> callback,
       Executor executor)  | 
Copyright © 2019 Hazelcast, Inc.. All Rights Reserved.