| 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.cp.internal.client | |
| com.hazelcast.cp.internal.datastructures.atomiclong.client | Client protocol tasks for the Raft-based AtomicLong implementation | 
| com.hazelcast.cp.internal.datastructures.atomicref.client | Client protocol tasks for the Raft-based AtomicReference implementation | 
| com.hazelcast.cp.internal.datastructures.countdownlatch.client | Client protocol tasks for the Raft-based CountDownLatch implementation | 
| com.hazelcast.cp.internal.datastructures.lock.client | Client protocol tasks for the Raft-based Lock implementation | 
| com.hazelcast.cp.internal.datastructures.semaphore.client | Client protocol tasks for the Raft-based Semaphore implementation | 
| com.hazelcast.cp.internal.datastructures.spi.client | Contains utilities for creating Raft groups and fetching Raft group ids
 from clients | 
| com.hazelcast.cp.internal.operation | Contains operations for the Raft Invocation SPI | 
| com.hazelcast.cp.internal.session.client | Client protocol tasks for the Raft-based Session implementation | 
| com.hazelcast.executor.impl | This package contains IExecutorService functionality for Hazelcast. The IExecutorService extends the ExecutorServiceand 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  InternalOperationServiceAPI. | 
| com.hazelcast.spi.impl.operationservice.impl | Contains the code for the  InternalOperationServiceimplementation. | 
| 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  | AuthenticationCustomCredentialsMessageTaskCustom Authentication with custom credential impl | 
| class  | AuthenticationMessageTaskDefault 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  | CacheClearMessageTaskThis client request  specifically calls  CacheClearOperationFactoryon the server side. | 
| class  | CacheContainsKeyMessageTaskThis client request  specifically calls  CacheContainsKeyOperationon the server side. | 
| class  | CacheCreateConfigMessageTaskCreates the given CacheConfig on all members of the cluster. | 
| class  | CacheDestroyMessageTask | 
| class  | CacheEntryProcessorMessageTaskThis client request  specifically calls  CacheEntryProcessorOperationon the server side. | 
| class  | CacheEventJournalReadTask<K,V,T>Reads from the cache event journal in batches. | 
| class  | CacheEventJournalSubscribeTaskPerforms the initial subscription to the cache event journal. | 
| class  | CacheFetchNearCacheInvalidationMetadataTask | 
| class  | CacheGetAllMessageTaskThis client request  specifically calls  CacheGetAllOperationFactoryon the server side. | 
| class  | CacheGetAndRemoveMessageTaskThis client request  specifically calls  CacheGetAndRemoveOperationon the server side. | 
| class  | CacheGetAndReplaceMessageTaskThis client request specifically calls  CacheGetAndReplaceOperationon the server side. | 
| class  | CacheGetConfigMessageTaskThis client request specifically calls  CacheGetConfigOperationon the server side. | 
| class  | CacheGetMessageTaskThis client request  specifically calls  CacheGetOperationon the server side. | 
| class  | CacheIterateEntriesMessageTaskThis client request specifically calls  CacheEntryIteratorOperationon the server side. | 
| class  | CacheIterateMessageTaskThis client request  specifically calls  CacheKeyIteratorOperationon the server side. | 
| class  | CacheListenerRegistrationMessageTaskThis client request  specifically calls  CacheListenerRegistrationOperationon the server side. | 
| class  | CacheLoadAllMessageTaskThis client request  specifically calls  CacheLoadAllOperationFactoryon the server side. | 
| class  | CacheManagementConfigMessageTaskThis client request  specifically calls  CacheManagementConfigOperationon the server side. | 
| class  | CachePutAllMessageTaskThis client request specifically calls  CachePutAllOperationon the server side. | 
| class  | CachePutIfAbsentMessageTaskThis client request  specifically calls  CachePutIfAbsentOperationon the server side. | 
| class  | CachePutMessageTaskThis client request  specifically calls  CachePutOperationon the server side. | 
| class  | CacheRemoveAllKeysMessageTaskThis client request  specifically calls  CacheRemoveAllOperationFactoryon the server side. | 
| class  | CacheRemoveAllMessageTaskThis client request  specifically calls  CacheRemoveAllOperationFactoryon the server side. | 
| class  | CacheRemoveMessageTaskThis client request  specifically calls  CacheRemoveOperationon the server side. | 
| class  | CacheReplaceMessageTaskThis client request specifically calls  CachePutOperationon the server side. | 
| class  | CacheSetExpiryPolicyMessageTask | 
| class  | CacheSizeMessageTaskThis client request specifically calls  CacheSizeOperationFactoryon 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  | PNCounterAddMessageTaskTask responsible for processing client messages for updating the
  PNCounterstate. | 
| class  | PNCounterGetMessageTaskTask responsible for processing client messages for retrieving the
 current  PNCounterstate. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ExecutorServiceCancelOnAddressMessageTask | 
| class  | ExecutorServiceCancelOnPartitionMessageTask | 
| 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  | ListAddAllMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_ADDALL | 
| class  | ListAddAllWithIndexMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_ADDALLWITHINDEX | 
| class  | ListAddMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_ADD | 
| class  | ListAddWithIndexMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_ADDWITHINDEX | 
| class  | ListClearMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_CLEAR | 
| class  | ListCompareAndRemoveAllMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_COMPAREANDREMOVEALL | 
| class  | ListCompareAndRetainAllMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_COMPAREANDRETAINALL | 
| class  | ListContainsAllMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_CONTAINSALL | 
| class  | ListContainsMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_CONTAINS | 
| class  | ListGetAllMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_GETALL | 
| class  | ListGetMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_GET | 
| class  | ListIndexOfMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_INDEXOF | 
| class  | ListIsEmptyMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_ADDLISTENER | 
| class  | ListIteratorMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_ITERATOR | 
| class  | ListLastIndexOfMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_LASTINDEXOF | 
| class  | ListListIteratorMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_LISTITERATOR | 
| class  | ListRemoveMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_REMOVE | 
| class  | ListRemoveWithIndexMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_REMOVEWITHINDEX | 
| class  | ListSetMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_SET | 
| class  | ListSizeMessageTaskClient Protocol Task for handling messages with type ID:
  ListMessageType.LIST_SIZE | 
| class  | ListSubMessageTaskClient 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  | MultiMapClearMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_CLEAR | 
| class  | MultiMapContainsEntryMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_CONTAINSENTRY | 
| class  | MultiMapContainsKeyMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_CONTAINSKEY | 
| class  | MultiMapContainsValueMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_CONTAINSVALUE | 
| class  | MultiMapDeleteMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_DELETE | 
| class  | MultiMapEntrySetMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_ENTRYSET | 
| class  | MultiMapForceUnlockMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_FORCEUNLOCK | 
| class  | MultiMapGetMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_GET | 
| class  | MultiMapIsLockedMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_ISLOCKED | 
| class  | MultiMapKeySetMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_KEYSET | 
| class  | MultiMapLockMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_LOCK | 
| class  | MultiMapPutMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_PUT | 
| class  | MultiMapRemoveEntryMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_REMOVEENTRY | 
| class  | MultiMapRemoveMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_REMOVE | 
| class  | MultiMapSizeMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_SIZE | 
| class  | MultiMapTryLockMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_TRYLOCK | 
| class  | MultiMapUnlockMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_UNLOCK | 
| class  | MultiMapValueCountMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_VALUECOUNT | 
| class  | MultiMapValuesMessageTaskClient Protocol Task for handling messages with type ID:
  MultiMapMessageType.MULTIMAP_VALUES | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueueAddAllMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_ADDLISTENER | 
| class  | QueueClearMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_CLEAR | 
| class  | QueueCompareAndRemoveAllMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_COMPAREANDREMOVEALL | 
| class  | QueueCompareAndRetainAllMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_COMPAREANDRETAINALL | 
| class  | QueueContainsAllMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_CONTAINSALL | 
| class  | QueueContainsMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_CONTAINS | 
| class  | QueueDrainMaxSizeMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_DRAINTOMAXSIZE | 
| class  | QueueDrainMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_DRAINTO | 
| class  | QueueIsEmptyMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_ISEMPTY | 
| class  | QueueIteratorMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_ITERATOR | 
| class  | QueueOfferMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_OFFER | 
| class  | QueuePeekMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_PEEK | 
| class  | QueuePollMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_POLL | 
| class  | QueuePutMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_PUT | 
| class  | QueueRemainingCapacityMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_REMAININGCAPACITY | 
| class  | QueueRemoveMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_REMOVE | 
| class  | QueueSizeMessageTaskClient Protocol Task for handling messages with type ID:
  QueueMessageType.QUEUE_SIZE | 
| class  | QueueTakeMessageTaskClient 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  | RingbufferAddAllMessageTaskClient Protocol Task for handling messages with type ID:
  RingbufferMessageType.RINGBUFFER_ADDALL | 
| class  | RingbufferAddMessageTaskClient Protocol Task for handling messages with type ID:
  RingbufferMessageType.RINGBUFFER_ADD | 
| class  | RingbufferCapacityMessageTask | 
| class  | RingbufferHeadSequenceMessageTask | 
| class  | RingbufferReadManyMessageTaskClient Protocol Task for handling messages with type ID:
  RingbufferMessageType.RINGBUFFER_READMANY | 
| class  | RingbufferReadOneMessageTaskClient 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  | SetAddAllMessageTaskSetAddAllMessageTask | 
| class  | SetAddMessageTaskSetAddMessageTask | 
| class  | SetClearMessageTaskSetClearMessageTask | 
| class  | SetCompareAndRemoveAllMessageTaskSetCompareAndRemoveAllMessageTask | 
| class  | SetCompareAndRetainAllMessageTaskSetCompareAndRetainAllMessageTask | 
| class  | SetContainsAllMessageTaskSetContainsAllMessageTask | 
| class  | SetContainsMessageTaskSetContainsMessageTask | 
| class  | SetGetAllMessageTaskSetGetAllMessageTask | 
| class  | SetIsEmptyMessageTaskSetIsEmptyMessageTask | 
| class  | SetRemoveMessageTaskSetRemoveMessageTask | 
| class  | SetSizeMessageTaskSetSizeMessageTask | 
| 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) | 
| 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  EntryProcessorto the entry mapped by thekeywith
 specifiedExecutionCallbackto 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 | Class and Description | 
|---|---|
| class  | AbstractCPMessageTask<P> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddAndGetMessageTaskClient message task for  AddAndGetOp | 
| class  | AlterMessageTaskClient message task for  AlterOp | 
| class  | GetAndAddMessageTaskClient message task for  GetAndAddOp | 
| class  | GetAndSetMessageTaskClient message task for  GetAndSetOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ApplyMessageTaskClient message task for  ApplyOp | 
| class  | CompareAndSetMessageTaskClient message task for  CompareAndSetOp | 
| class  | ContainsMessageTaskClient message task for  ContainsOp | 
| class  | GetMessageTaskClient message task for  GetOp | 
| class  | SetMessageTaskClient message task for  SetOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AwaitMessageTaskClient message task for  AwaitOp | 
| class  | CountDownMessageTaskClient message task for  CountDownOp | 
| class  | GetCountMessageTaskClient message task for  GetCountOp | 
| class  | GetRoundMessageTaskClient message task for  GetRoundOp | 
| class  | TrySetCountMessageTaskClient message task for  TrySetCountOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | GetLockOwnershipStateMessageTaskClient message task for  GetLockOwnershipStateOp | 
| class  | LockMessageTaskClient message task for  LockOp | 
| class  | TryLockMessageTaskClient message task for  TryLockOp | 
| class  | UnlockMessageTaskClient message task for  UnlockOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AcquirePermitsMessageTaskClient message task for  AcquirePermitsOp | 
| class  | AvailablePermitsMessageTaskClient message task for  AvailablePermitsOp | 
| class  | ChangePermitsMessageTaskClient message task for  ChangePermitsOp | 
| class  | DrainPermitsMessageTaskClient message task for  DrainPermitsOp | 
| class  | InitSemaphoreMessageTaskClient message task for  InitSemaphoreOp | 
| class  | ReleasePermitsMessageTaskClient message task for  ReleasePermitsOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CreateRaftGroupMessageTaskClient message task for Raft group creation | 
| class  | DestroyRaftObjectMessageTaskClient message task for destroying Raft objects | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ChangeRaftGroupMembershipOpReplicates a membership change operation to a Raft group. | 
| class  | DefaultRaftReplicateOpThe operation used by  RaftInvocationManagerto replicate a givenRaftOpto leader of the target Raft group. | 
| class  | DestroyRaftGroupOpReplicates a  DestroyRaftGroupCmdto a Raft group. | 
| class  | RaftQueryOpThe operation that passes a query to leader or a follower of a Raft group. | 
| class  | RaftReplicateOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CloseSessionMessageTaskClient message task for  CloseSessionOp | 
| class  | CreateSessionMessageTaskClient message task for  CreateSessionOp | 
| class  | GenerateThreadIdMessageTaskClient message task for  GenerateThreadIdOp | 
| class  | HeartbeatSessionMessageTaskClient message task for  HeartbeatSessionOp | 
| 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) | 
| 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 | 
|---|---|
| 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) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MessageRunner<E>An  ExecutionCallbackthat 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 © 2022 Hazelcast, Inc.. All Rights Reserved.