| Package | Description | 
|---|---|
| com.hazelcast.cache.impl.client | 
     Hazelcast JSR-107 aka JCache implementation
     Client Requests | 
| com.hazelcast.client.impl.client | This contains the Requests and other DTO's exchanged between client/server | 
| 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.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.executorservice | Client protocol tasks implementations for ExecutorService | 
| 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.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 com.hazelcast.client | 
| com.hazelcast.client.util | This package contains some utility classes and the base implementations of the
 loadbalancer implementations | 
| com.hazelcast.collection.impl.collection.client | |
| com.hazelcast.collection.impl.list.client | |
| com.hazelcast.collection.impl.queue.client | This package contains client requests for the IQueue. | 
| 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.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.countdownlatch.client | This package contains client requests for the ICountDownLatch. This package contains all the client requests object to operate on the ICountDownLatch that are send by the client. | 
| 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.semaphore.client | This package contains client requests for the ISemaphore. | 
| com.hazelcast.core | Provides core API interfaces/classes. | 
| 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.executor.impl.client | This package contains client requests for the IExecutorService. | 
| com.hazelcast.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.client | Contains client requests for the  IMap | 
| com.hazelcast.map.impl.proxy | Contains map proxy implementation and support classes. | 
| com.hazelcast.map.impl.recordstore | |
| com.hazelcast.multimap.impl.client | Contains client requests for Hazelcast MultiMap module. | 
| com.hazelcast.replicatedmap.impl.client | This package contains classes for client communication on replicated map implementation | 
| com.hazelcast.ringbuffer.impl.client | |
| com.hazelcast.spi | Provides interfaces/classes for Hazelcast SPI. | 
| 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.client | This package contains client requests for the ITopic. | 
| com.hazelcast.transaction.client | This package contains client transaction code | 
| 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 | Class and Description | 
|---|---|
| class  | AbstractCacheRequest | 
| class  | CacheContainsKeyRequestThis client request  specifically calls  CacheContainsKeyOperationon the server side. | 
| class  | CacheEntryProcessorRequestThis client request  specifically calls  CacheEntryProcessorOperationon the server side. | 
| class  | CacheGetAndRemoveRequestThis client request  specifically calls  CacheGetAndRemoveOperationon the server side. | 
| class  | CacheGetAndReplaceRequestThis client request  specifically calls  CacheGetAndReplaceOperationon the server side. | 
| class  | CacheGetConfigRequestThis client request  specifically calls  CacheGetConfigOperationon the server side. | 
| class  | CacheGetRequestThis client request  specifically calls  CacheGetOperationon the server side. | 
| class  | CacheIterateRequestThis client request  specifically calls  CacheKeyIteratorOperationon the server side. | 
| class  | CacheListenerRegistrationRequestThis client request  specifically calls  CacheListenerRegistrationOperationon the server side. | 
| class  | CacheManagementConfigRequestThis client request  specifically calls  CacheManagementConfigOperationon the server side. | 
| class  | CachePutAllRequestThis client request that puts entries as batch into specified partition. | 
| class  | CachePutIfAbsentRequestThis client request  specifically calls  CachePutIfAbsentOperationon the server side. | 
| class  | CachePutRequestThis client request  specifically calls  CachePutOperationon the server side. | 
| class  | CacheRemoveRequestThis client request  specifically calls  CacheRemoveOperationon the server side. | 
| class  | CacheReplaceRequestThis client request  specifically calls  CacheReplaceOperationon the server side. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientCreateRequest | 
| class  | KeyBasedClientRequest | 
| class  | PartitionClientRequestBase class for partition based client request. | 
| class  | TargetClientRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractInvocationMessageTask<P> | 
| class  | AbstractPartitionMessageTask<P>AbstractPartitionMessageTask | 
| 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  | CacheContainsKeyMessageTaskThis client request  specifically calls  CacheContainsKeyOperationon the server side. | 
| class  | CacheCreateConfigMessageTaskThis client request  specifically calls  CacheCreateConfigOperationon the server side. | 
| class  | CacheDestroyMessageTask | 
| class  | CacheEntryProcessorMessageTaskThis client request  specifically calls  CacheEntryProcessorOperationon 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  | CacheIterateMessageTaskThis client request  specifically calls  CacheKeyIteratorOperationon the server side. | 
| class  | CacheListenerRegistrationMessageTaskThis client request  specifically calls  CacheListenerRegistrationOperationon 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  | CacheRemoveMessageTaskThis client request  specifically calls  CacheRemoveOperationon the server side. | 
| class  | CacheReplaceMessageTaskThis client request  specifically calls  CachePutOperationon the server side. | 
| 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  | ExecutorServiceSubmitToAddressMessageTask | 
| class  | ExecutorServiceSubmitToPartitionMessageTask | 
| 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  | AbstractMapPutMessageTask<P> | 
| class  | MapClearNearCacheMessageTask | 
| class  | MapContainsKeyMessageTask | 
| class  | MapDeleteMessageTask | 
| class  | MapEvictMessageTask | 
| class  | MapExecuteOnKeyMessageTask | 
| class  | MapForceUnlockMessageTask | 
| class  | MapGetAllMessageTask | 
| class  | MapGetAsyncMessageTask | 
| class  | MapGetEntryViewMessageTask | 
| class  | MapGetMessageTask | 
| class  | MapIsLockedMessageTask | 
| class  | MapLockMessageTask | 
| class  | MapPutAllMessageTask | 
| class  | MapPutAsyncMessageTask | 
| class  | MapPutIfAbsentMessageTask | 
| class  | MapPutMessageTask | 
| class  | MapPutTransientMessageTask | 
| class  | MapRemoveAsyncMessageTask | 
| class  | MapRemoveIfSameMessageTask | 
| class  | MapRemoveMessageTask | 
| class  | MapReplaceIfSameMessageTask | 
| class  | MapReplaceMessageTask | 
| class  | MapSetMessageTask | 
| class  | MapSubmitToKeyMessageTask | 
| class  | MapTryLockMessageTask | 
| class  | MapTryPutMessageTask | 
| class  | MapTryRemoveMessageTask | 
| class  | MapUnlockMessageTask | 
| 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  | 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  | 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  | 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  | 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 | 
| 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  | ReplicatedMapPutMessageTask | 
| class  | ReplicatedMapRemoveMessageTask | 
| class  | ReplicatedMapSizeMessageTask | 
| class  | ReplicatedMapValuesMessageTask | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RingbufferAddAllAsyncMessageTaskClient Protocol Task for handling messages with type id:
  QueueMessageType.QUEUE_OFFER | 
| class  | RingbufferAddAsyncMessageTaskClient Protocol Task for handling messages with type id:
  QueueMessageType.QUEUE_OFFER | 
| class  | RingbufferAddMessageTaskClient Protocol Task for handling messages with type id:
  QueueMessageType.QUEUE_OFFER | 
| class  | RingbufferCapacityMessageTask | 
| class  | RingbufferHeadSequenceMessageTask | 
| class  | RingbufferReadManyAsyncMessageTaskClient Protocol Task for handling messages with type id:
  QueueMessageType.QUEUE_OFFER | 
| class  | RingbufferReadOneMessageTaskClient Protocol Task for handling messages with type id:
  QueueMessageType.QUEUE_OFFER | 
| class  | RingbufferRemainingCapacityMessageTask | 
| class  | RingbufferSizeMessageTask | 
| class  | RingbufferTailSequenceMessageTask | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SemaphoreAcquireMessageTask | 
| class  | SemaphoreAvailablePermitsMessageTasks | 
| class  | SemaphoreDrainPermitsMessageTask | 
| 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 | 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) | 
| <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) | 
| void | ClientInvocationFuture. andThenInternal(ExecutionCallback<ClientMessage> callback) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ClientDelegatingFuture. andThen(ExecutionCallback<V> callback) | 
| void | ClientDelegatingFuture. andThen(ExecutionCallback<V> callback,
       Executor executor) | 
| <R> void | ClientDelegatingFuture. andThenInternal(ExecutionCallback<R> callback) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CollectionAddAllRequest | 
| class  | CollectionAddRequest | 
| class  | CollectionClearRequest | 
| class  | CollectionCompareAndRemoveRequest | 
| class  | CollectionContainsRequest | 
| class  | CollectionGetAllRequest | 
| class  | CollectionIsEmptyRequest | 
| class  | CollectionRemoveRequest | 
| class  | CollectionRequest | 
| class  | CollectionSizeRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ListAddAllRequest | 
| class  | ListAddRequest | 
| class  | ListGetRequest | 
| class  | ListIndexOfRequest | 
| class  | ListRemoveRequest | 
| class  | ListSetRequest | 
| class  | ListSubRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClearRequestProvides the request service for  ClearOperation | 
| class  | CompareAndRemoveRequestProvides the request service for  CompareAndRemoveOperation | 
| class  | ContainsRequestProvides the request service for  ContainsOperation | 
| class  | DrainRequestProvides the request service for  DrainOperation | 
| class  | IsEmptyRequestRequest to check if the Queue is empty | 
| class  | IteratorRequestProvides the request service for  IteratorOperation | 
| class  | OfferRequestProvides the request service for  OfferOperation | 
| class  | PeekRequestProvides the request service for  PeekOperation | 
| class  | PollRequestProvides the request service for  PollOperation | 
| class  | QueueRequestThis class contains methods for all Queue requests
 such as  ClearRequest. | 
| class  | RemoveRequestRemove Request for the Queue. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddAndGetRequest | 
| class  | AtomicLongRequest | 
| class  | GetAndAddRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAlterRequest | 
| class  | AlterAndGetRequest | 
| class  | AlterRequest | 
| class  | ApplyRequest | 
| class  | CompareAndSetRequest | 
| class  | GetAndAlterRequest | 
| class  | GetAndSetRequest | 
| class  | GetRequest | 
| class  | IsNullRequest | 
| class  | ModifyRequest | 
| class  | ReadRequest | 
| class  | SetRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AwaitRequest | 
| class  | CountDownRequest | 
| class  | GetCountRequest | 
| class  | SetCountRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractIsLockedRequest | 
| class  | AbstractLockRequest | 
| class  | AbstractUnlockRequest | 
| class  | BeforeAwaitRequest | 
| class  | GetLockCountRequest | 
| class  | GetRemainingLeaseRequest | 
| class  | IsLockedRequest | 
| class  | LockRequest | 
| class  | SignalRequest | 
| class  | UnlockRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AcquireRequest | 
| class  | AvailableRequest | 
| class  | InitRequest | 
| class  | ReduceRequest | 
| class  | ReleaseRequest | 
| class  | SemaphoreRequest | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ICompletableFuture. andThen(ExecutionCallback<V> callback)Registers a callback that will run after the future is completed. | 
| void | ICompletableFuture. andThen(ExecutionCallback<V> callback,
       Executor executor)Registers a callback that will run with the provided executor after the 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) | 
| Constructor and Description | 
|---|
| ExecutionCallbackAdapter(ExecutionCallback executionCallback) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PartitionTargetCallableRequestA  TargetClientRequestwhich sends aCallabletask
 to a specific target. | 
| class  | SpecificTargetCallableRequestA  TargetClientRequestwhich sends
 aCallabletask to the given target address. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MapKeyLoader. onKeyLoad(ExecutionCallback<Boolean> callback) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapClearNearCacheRequest | 
| class  | MapContainsKeyRequest | 
| class  | MapDeleteRequest | 
| class  | MapEvictRequest | 
| class  | MapExecuteOnKeyRequest | 
| class  | MapGetAllRequest | 
| class  | MapGetEntryViewRequest | 
| class  | MapGetRequest | 
| class  | MapIsLockedRequest | 
| class  | MapKeyBasedClientRequest | 
| class  | MapLockRequest | 
| class  | MapPartitionClientRequest | 
| class  | MapPutAllRequest | 
| class  | MapPutIfAbsentRequest | 
| class  | MapPutRequest | 
| class  | MapPutTransientRequest | 
| class  | MapRemoveIfSameRequest | 
| class  | MapRemoveRequest | 
| class  | MapReplaceIfSameRequest | 
| class  | MapReplaceRequest | 
| class  | MapSetRequest | 
| class  | MapTryPutRequest | 
| class  | MapTryRemoveRequest | 
| class  | MapUnlockRequest | 
| Modifier and Type | Method and Description | 
|---|---|
| ICompletableFuture | NearCachedMapProxyImpl. executeOnKeyInternal(Data key,
                    EntryProcessor entryProcessor,
                    ExecutionCallback callback) | 
| void | MapProxyImpl. submitToKey(K key,
           EntryProcessor entryProcessor,
           ExecutionCallback callback) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RecordStore. onKeyLoad(ExecutionCallback<Boolean> callback)Register a callback for when key loading is complete | 
| void | DefaultRecordStore. onKeyLoad(ExecutionCallback<Boolean> callback) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CountRequest | 
| class  | GetAllRequest | 
| class  | KeyBasedContainsRequestThe KeyBasedContainsRequest can be used to determine if a key is available in a multimap (when value is null), or
 to check if a map-entry is stored in the multimap (value not null). | 
| class  | MultiMapIsLockedRequest | 
| class  | MultiMapKeyBasedRequest | 
| class  | MultiMapLockRequest | 
| class  | MultiMapRequest | 
| class  | MultiMapUnlockRequest | 
| class  | PutRequest | 
| class  | RemoveAllRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddAllRequest | 
| class  | AddAsyncRequest | 
| class  | AddRequest | 
| class  | CapacityRequest | 
| class  | HeadSequenceRequest | 
| class  | ReadManyRequest | 
| class  | ReadOneRequest | 
| class  | RemainingCapacityRequest | 
| class  | RingbufferRequest | 
| class  | SizeRequest | 
| class  | TailSequenceRequest | 
| 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 | AbstractCompletableFuture. 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) | 
| Constructor and Description | 
|---|
| PartitionInvocation(NodeEngineImpl nodeEngine,
                   String serviceName,
                   Operation op,
                   int partitionId,
                   int replicaIndex,
                   int tryCount,
                   long tryPauseMillis,
                   long callTimeout,
                   ExecutionCallback callback,
                   boolean resultDeserialized) | 
| TargetInvocation(NodeEngineImpl nodeEngine,
                String serviceName,
                Operation op,
                Address target,
                int tryCount,
                long tryPauseMillis,
                long callTimeout,
                ExecutionCallback callback,
                boolean resultDeserialized) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PublishRequest | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FinalizeXATransactionRequest | 
| 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 © 2015 Hazelcast, Inc.. All Rights Reserved.