Uses of Interface
com.hazelcast.core.ExecutionCallback

Packages that use ExecutionCallback
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.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.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.collection.impl.txncollection   
com.hazelcast.collection.impl.txnqueue   
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 ExecutorService and 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.client Contains client requests for the IMap 
com.hazelcast.map.impl.proxy Contains map proxy implementation and support classes. 
com.hazelcast.map.impl.tx Contains implementation classes for TransactionalMap 
com.hazelcast.multimap.impl.client Contains client requests for Hazelcast MultiMap module. 
com.hazelcast.multimap.impl.txn This package contains the Transaction behavior for the Multimap.
 
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 InternalOperationService API. 
com.hazelcast.spi.impl.operationservice.impl Contains the code for the InternalOperationService implementation. 
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.util.executor This package contains classes related to Util.Executor
 
 

Uses of ExecutionCallback in com.hazelcast.cache.impl.client
 

Classes in com.hazelcast.cache.impl.client that implement ExecutionCallback
 class AbstractCacheRequest
          Abstract cache request to handle a completion id registration.
 class CacheContainsKeyRequest
          This client request specifically calls CacheContainsKeyOperation on the server side.
 class CacheEntryProcessorRequest
          This client request specifically calls CacheEntryProcessorOperation on the server side.
 class CacheGetAndRemoveRequest
          This client request specifically calls CacheGetAndRemoveOperation on the server side.
 class CacheGetAndReplaceRequest
          This client request specifically calls CacheGetAndReplaceOperation on the server side.
 class CacheGetConfigRequest
          This client request specifically calls CacheGetConfigOperation on the server side.
 class CacheGetRequest
          This client request specifically calls CacheGetOperation on the server side.
 class CacheIterateRequest
          This client request specifically calls CacheKeyIteratorOperation on the server side.
 class CacheListenerRegistrationRequest
          This client request specifically calls CacheListenerRegistrationOperation on the server side.
 class CacheManagementConfigRequest
          This client request specifically calls CacheManagementConfigOperation on the server side.
 class CachePutIfAbsentRequest
          This client request specifically calls CachePutIfAbsentOperation on the server side.
 class CachePutRequest
          This client request specifically calls CachePutOperation on the server side.
 class CacheRemoveRequest
          This client request specifically calls CacheRemoveOperation on the server side.
 class CacheReplaceRequest
          This client request specifically calls CacheReplaceOperation on the server side.
 

Uses of ExecutionCallback in com.hazelcast.client.impl.client
 

Classes in com.hazelcast.client.impl.client that implement ExecutionCallback
 class KeyBasedClientRequest
           
 class PartitionClientRequest
          Base class for partition based client request.
 class TargetClientRequest
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task
 

Classes in com.hazelcast.client.impl.protocol.task that implement ExecutionCallback
 class AbstractPartitionMessageTask<P>
          AbstractPartitionMessageTask
 class InvocationMessageTask<P>
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.atomiclong
 

Classes in com.hazelcast.client.impl.protocol.task.atomiclong that implement ExecutionCallback
 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
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.atomicreference
 

Classes in com.hazelcast.client.impl.protocol.task.atomicreference that implement ExecutionCallback
 class AtomicRefenceContainsMessageTask
           
 class AtomicReferenceAlterAndGetMessageTask
           
 class AtomicReferenceAlterMessageTask
           
 class AtomicReferenceApplyMessageTask
           
 class AtomicReferenceClearMessageTask
           
 class AtomicReferenceCompareAndSetMessageTask
           
 class AtomicReferenceGetAndAlterMessageTask
           
 class AtomicReferenceGetAndSetMessageTask
           
 class AtomicReferenceGetMessageTask
           
 class AtomicReferenceIsNullMessageTask
           
 class AtomicReferenceSetAndGetMessageTask
           
 class AtomicReferenceSetMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.cache
 

Classes in com.hazelcast.client.impl.protocol.task.cache that implement ExecutionCallback
 class AbstractCacheMessageTask<P>
          Abstract Cache request to handle InMemoryFormat which needed for operation provider
 class CacheContainsKeyMessageTask
          This client request specifically calls CacheContainsKeyOperation on the server side.
 class CacheCreateConfigMessageTask
          This client request specifically calls CacheCreateConfigOperation on the server side.
 class CacheDestroyMessageTask
          This client request specifically calls CacheDestroyParameters on the server side.
 class CacheEntryProcessorMessageTask
          This client request specifically calls CacheEntryProcessorOperation 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 CacheIterateMessageTask
          This client request specifically calls CacheKeyIteratorOperation on the server side.
 class CacheListenerRegistrationMessageTask
          This client request specifically calls CacheListenerRegistrationOperation on the server side.
 class CacheManagementConfigMessageTask
          This client request specifically calls CacheManagementConfigOperation 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 CacheRemoveMessageTask
          This client request specifically calls CacheRemoveOperation on the server side.
 class CacheReplaceMessageTask
          This client request specifically calls CachePutOperation on the server side.
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.condition
 

Classes in com.hazelcast.client.impl.protocol.task.condition that implement ExecutionCallback
 class ConditionAwaitMessageTask
           
 class ConditionBeforeAwaitMessageTask
           
 class ConditionSignalAllMessageTask
           
 class ConditionSignalMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.countdownlatch
 

Classes in com.hazelcast.client.impl.protocol.task.countdownlatch that implement ExecutionCallback
 class CountDownLatchAwaitMessageTask
           
 class CountDownLatchCountDownMessageTask
           
 class CountDownLatchGetCountMessageTask
           
 class CountDownLatchTrySetCountMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.executorservice
 

Classes in com.hazelcast.client.impl.protocol.task.executorservice that implement ExecutionCallback
 class ExecutorServiceSubmitToAddressMessageTask
           
 class ExecutorServiceSubmitToPartitionMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.list
 

Classes in com.hazelcast.client.impl.protocol.task.list that implement ExecutionCallback
 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: com.hazelcast.client.impl.protocol.parameters.ListMessageType#QUEUE_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 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
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.lock
 

Classes in com.hazelcast.client.impl.protocol.task.lock that implement ExecutionCallback
 class LockForceUnlockMessageTask
           
 class LockGetLockCountMessageTask
           
 class LockGetRemainingLeaseTimeMessageTask
           
 class LockIsLockedByCurrentThreadMessageTask
           
 class LockIsLockedMessageTask
           
 class LockLockMessageTask
           
 class LockTryLockMessageTask
           
 class LockUnlockMessagetask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.map
 

Classes in com.hazelcast.client.impl.protocol.task.map that implement ExecutionCallback
 class AbstractMapPutMessageTask<P>
           
 class MapContainsKeyMessageTask
           
 class MapDeleteMessageTask
           
 class MapEvictMessageTask
           
 class MapExecuteOnKeyMessageTask
           
 class MapForceUnlockMessageTask
           
 class MapGetAsyncMessageTask
           
 class MapGetEntryViewMessageTask
           
 class MapGetMessageTask
           
 class MapIsLockedMessageTask
           
 class MapLockMessageTask
          Client Protocol Task for handling messages with type id: MapMessageType.MAP_LOCK
 class MapPutAsyncMessageTask
           
 class MapPutIfAbsentMessageTask
           
 class MapPutMessageTask
           
 class MapPutTransientMessageTask
           
 class MapRemoveAsyncMessageTask
           
 class MapRemoveIfSameMessageTask
           
 class MapRemoveMessageTask
           
 class MapReplaceIfSameMessageTask
           
 class MapReplaceMessageTask
           
 class MapSetMessageTask
           
 class MapSubmitToKeyMessageTask
           
 class MapTryLockMessageTask
          Client Protocol Task for handling messages with type id: MapMessageType.MAP_TRYLOCK
 class MapTryPutMessageTask
           
 class MapTryRemoveMessageTask
           
 class MapUnlockMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.mapreduce
 

Classes in com.hazelcast.client.impl.protocol.task.mapreduce that implement ExecutionCallback
 class AbstractMapReduceTask<Parameters>
           
 class MapReduceForCustomMessageTask
           
 class MapReduceForListMessageTask
           
 class MapReduceForMapMessageTask
           
 class MapReduceForMultiMapMessageTask
           
 class MapReduceForSetMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.multimap
 

Classes in com.hazelcast.client.impl.protocol.task.multimap that implement ExecutionCallback
 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 MultiMapCountMessageTask
          Client Protocol Task for handling messages with type id: MultiMapMessageType.MULTIMAP_COUNT
 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 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 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
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.queue
 

Classes in com.hazelcast.client.impl.protocol.task.queue that implement ExecutionCallback
 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
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.semaphore
 

Classes in com.hazelcast.client.impl.protocol.task.semaphore that implement ExecutionCallback
 class SemaphoreAcquireMessageTask
           
 class SemaphoreAvailablePermitsMessageTasks
           
 class SemaphoreDrainPermitsMessageTask
           
 class SemaphoreInitMessageTask
           
 class SemaphoreReducePermitsMessageTask
           
 class SemaphoreReleaseMessageTask
           
 class SemaphoreTryAcquireMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.set
 

Classes in com.hazelcast.client.impl.protocol.task.set that implement ExecutionCallback
 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
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.topic
 

Classes in com.hazelcast.client.impl.protocol.task.topic that implement ExecutionCallback
 class TopicPublishMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.impl.protocol.task.transaction
 

Classes in com.hazelcast.client.impl.protocol.task.transaction that implement ExecutionCallback
 class XAFinalizeTransactionMessageTask
           
 

Uses of ExecutionCallback in com.hazelcast.client.proxy
 

Methods in com.hazelcast.client.proxy with parameters of type ExecutionCallback
<T> void
ClientExecutorServiceProxy.submit(Callable<T> task, ExecutionCallback<T> callback)
           
<T> void
ClientExecutorServiceProxy.submit(Callable<T> task, MemberSelector memberSelector, ExecutionCallback<T> callback)
           
 void ClientExecutorServiceProxy.submit(Runnable command, ExecutionCallback 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)
           
 

Uses of ExecutionCallback in com.hazelcast.client.spi.impl
 

Methods in com.hazelcast.client.spi.impl with parameters of type ExecutionCallback
 void ClientInvocationFuture.andThen(ExecutionCallback<V> callback)
           
 void ClientInvocationFuture.andThen(ExecutionCallback<V> callback, Executor executor)
           
 void ClientInvocationFuture.andThenInternal(ExecutionCallback<Data> callback)
           
 

Uses of ExecutionCallback in com.hazelcast.collection.impl.collection.client
 

Classes in com.hazelcast.collection.impl.collection.client that implement ExecutionCallback
 class CollectionAddAllRequest
           
 class CollectionAddRequest
           
 class CollectionClearRequest
           
 class CollectionCompareAndRemoveRequest
           
 class CollectionContainsRequest
           
 class CollectionGetAllRequest
           
 class CollectionIsEmptyRequest
           
 class CollectionRemoveRequest
           
 class CollectionRequest
           
 class CollectionSizeRequest
           
 

Uses of ExecutionCallback in com.hazelcast.collection.impl.list.client
 

Classes in com.hazelcast.collection.impl.list.client that implement ExecutionCallback
 class ListAddAllRequest
           
 class ListAddRequest
           
 class ListGetRequest
           
 class ListIndexOfRequest
           
 class ListRemoveRequest
           
 class ListSetRequest
           
 class ListSubRequest
           
 

Uses of ExecutionCallback in com.hazelcast.collection.impl.queue.client
 

Classes in com.hazelcast.collection.impl.queue.client that implement ExecutionCallback
 class AddAllRequest
          Provides the request service for AddAllOperation
 class ClearRequest
          Provides the request service for ClearOperation
 class CompareAndRemoveRequest
          Provides the request service for CompareAndRemoveOperation
 class ContainsRequest
          Provides the request service for ContainsOperation
 class DrainRequest
          Provides the request service for DrainOperation
 class IsEmptyRequest
          Request to check if the Queue is empty
 class IteratorRequest
          Provides the request service for IteratorOperation
 class OfferRequest
          Provides the request service for OfferOperation
 class PeekRequest
          Provides the request service for PeekOperation
 class PollRequest
          Provides the request service for PollOperation
 class QueueRequest
          This class contains methods for all Queue requests such as ClearRequest.
 class RemainingCapacityRequest
          Request for remaining capacity of Queue.
 class RemoveRequest
          Remove Request for the Queue.
 class SizeRequest
          Request for size of the Queue.
 

Uses of ExecutionCallback in com.hazelcast.collection.impl.txncollection
 

Methods in com.hazelcast.collection.impl.txncollection with parameters of type ExecutionCallback
 void CollectionTransactionLog.commitAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 void CollectionTransactionLog.rollbackAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 

Uses of ExecutionCallback in com.hazelcast.collection.impl.txnqueue
 

Methods in com.hazelcast.collection.impl.txnqueue with parameters of type ExecutionCallback
 void QueueTransactionLog.commitAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 void QueueTransactionLog.rollbackAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 

Uses of ExecutionCallback in com.hazelcast.concurrent.atomiclong.client
 

Classes in com.hazelcast.concurrent.atomiclong.client that implement ExecutionCallback
 class AddAndGetRequest
           
 class AtomicLongRequest
           
 class GetAndAddRequest
           
 

Uses of ExecutionCallback in com.hazelcast.concurrent.atomicreference.client
 

Classes in com.hazelcast.concurrent.atomicreference.client that implement ExecutionCallback
 class AbstractAlterRequest
           
 class AlterAndGetRequest
           
 class AlterRequest
           
 class ApplyRequest
           
 class CompareAndSetRequest
           
 class GetAndAlterRequest
           
 class GetAndSetRequest
           
 class GetRequest
           
 class IsNullRequest
           
 class ModifyRequest
           
 class ReadRequest
           
 class SetRequest
           
 

Uses of ExecutionCallback in com.hazelcast.concurrent.countdownlatch.client
 

Classes in com.hazelcast.concurrent.countdownlatch.client that implement ExecutionCallback
 class AwaitRequest
           
 class CountDownRequest
           
 class GetCountRequest
           
 class SetCountRequest
           
 

Uses of ExecutionCallback in com.hazelcast.concurrent.lock.client
 

Classes in com.hazelcast.concurrent.lock.client that implement ExecutionCallback
 class AbstractIsLockedRequest
           
 class AbstractLockRequest
           
 class AbstractUnlockRequest
           
 class BeforeAwaitRequest
           
 class GetLockCountRequest
           
 class GetRemainingLeaseRequest
           
 class IsLockedRequest
           
 class LockRequest
           
 class SignalRequest
           
 class UnlockRequest
           
 

Uses of ExecutionCallback in com.hazelcast.concurrent.semaphore.client
 

Classes in com.hazelcast.concurrent.semaphore.client that implement ExecutionCallback
 class AcquireRequest
           
 class AvailableRequest
           
 class InitRequest
           
 class ReduceRequest
           
 class ReleaseRequest
           
 class SemaphoreRequest
           
 

Uses of ExecutionCallback in com.hazelcast.core
 

Methods in com.hazelcast.core with parameters of type ExecutionCallback
 void ICompletableFuture.andThen(ExecutionCallback<V> callback)
           
 void ICompletableFuture.andThen(ExecutionCallback<V> callback, Executor executor)
           
<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.
 

Uses of ExecutionCallback in com.hazelcast.executor.impl
 

Methods in com.hazelcast.executor.impl with parameters of type ExecutionCallback
<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)
           
 

Constructors in com.hazelcast.executor.impl with parameters of type ExecutionCallback
ExecutionCallbackAdapter(ExecutionCallback executionCallback)
           
 

Uses of ExecutionCallback in com.hazelcast.executor.impl.client
 

Classes in com.hazelcast.executor.impl.client that implement ExecutionCallback
 class PartitionTargetCallableRequest
          A TargetClientRequest which sends a Callable task to a specific target.
 class SpecificTargetCallableRequest
          A TargetClientRequest which sends a Callable task to the given target address.
 

Uses of ExecutionCallback in com.hazelcast.map.impl.client
 

Classes in com.hazelcast.map.impl.client that implement ExecutionCallback
 class MapContainsKeyRequest
           
 class MapDeleteRequest
           
 class MapEvictRequest
           
 class MapExecuteOnKeyRequest
           
 class MapGetEntryViewRequest
           
 class MapGetRequest
           
 class MapIsLockedRequest
           
 class MapLockRequest
           
 class MapPutIfAbsentRequest
           
 class MapPutRequest
           
 class MapPutTransientRequest
           
 class MapRemoveIfSameRequest
           
 class MapRemoveRequest
           
 class MapReplaceIfSameRequest
           
 class MapReplaceRequest
           
 class MapSetRequest
           
 class MapTryPutRequest
           
 class MapTryRemoveRequest
           
 class MapUnlockRequest
           
 

Uses of ExecutionCallback in com.hazelcast.map.impl.proxy
 

Methods in com.hazelcast.map.impl.proxy with parameters of type ExecutionCallback
 void MapProxyImpl.submitToKey(K key, EntryProcessor entryProcessor, ExecutionCallback callback)
           
 

Uses of ExecutionCallback in com.hazelcast.map.impl.tx
 

Methods in com.hazelcast.map.impl.tx with parameters of type ExecutionCallback
 void MapTransactionLog.commitAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 void MapTransactionLog.rollbackAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 

Uses of ExecutionCallback in com.hazelcast.multimap.impl.client
 

Classes in com.hazelcast.multimap.impl.client that implement ExecutionCallback
 class CountRequest
           
 class GetAllRequest
           
 class KeyBasedContainsRequest
          The 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
           
 

Uses of ExecutionCallback in com.hazelcast.multimap.impl.txn
 

Methods in com.hazelcast.multimap.impl.txn with parameters of type ExecutionCallback
 void MultiMapTransactionLog.commitAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 void MultiMapTransactionLog.rollbackAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 

Uses of ExecutionCallback in com.hazelcast.spi
 

Fields in com.hazelcast.spi declared as ExecutionCallback
protected  ExecutionCallback<Object> InvocationBuilder.executionCallback
           
 

Methods in com.hazelcast.spi that return ExecutionCallback
 ExecutionCallback<Object> InvocationBuilder.getExecutionCallback()
          Gets the ExecutionCallback.
 

Methods in com.hazelcast.spi with parameters of type ExecutionCallback
 InvocationBuilder InvocationBuilder.setExecutionCallback(ExecutionCallback<Object> executionCallback)
          Sets the ExecutionCallback.
 

Uses of ExecutionCallback in com.hazelcast.spi.impl
 

Methods in com.hazelcast.spi.impl with parameters of type ExecutionCallback
 void AbstractCompletableFuture.andThen(ExecutionCallback<V> callback)
           
 void AbstractCompletableFuture.andThen(ExecutionCallback<V> callback, Executor executor)
           
 

Uses of ExecutionCallback in com.hazelcast.spi.impl.operationservice
 

Methods in com.hazelcast.spi.impl.operationservice with parameters of type ExecutionCallback
<V> void
InternalOperationService.asyncInvokeOnPartition(String serviceName, Operation op, int partitionId, ExecutionCallback<V> callback)
           
<V> void
InternalOperationService.asyncInvokeOnTarget(String serviceName, Operation op, Address target, ExecutionCallback<V> callback)
           
 

Uses of ExecutionCallback in com.hazelcast.spi.impl.operationservice.impl
 

Methods in com.hazelcast.spi.impl.operationservice.impl with parameters of type ExecutionCallback
<V> void
OperationServiceImpl.asyncInvokeOnPartition(String serviceName, Operation op, int partitionId, ExecutionCallback<V> callback)
           
<V> void
OperationServiceImpl.asyncInvokeOnTarget(String serviceName, Operation op, Address target, ExecutionCallback<V> callback)
           
 

Uses of ExecutionCallback in com.hazelcast.topic.impl.client
 

Classes in com.hazelcast.topic.impl.client that implement ExecutionCallback
 class PublishRequest
           
 

Uses of ExecutionCallback in com.hazelcast.transaction.client
 

Classes in com.hazelcast.transaction.client that implement ExecutionCallback
 class FinalizeXATransactionRequest
           
 

Uses of ExecutionCallback in com.hazelcast.transaction.impl
 

Methods in com.hazelcast.transaction.impl with parameters of type ExecutionCallback
 void TransactionLog.commitAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 void TransactionLog.rollbackAsync(NodeEngine nodeEngine, ExecutionCallback callback)
           
 

Uses of ExecutionCallback in com.hazelcast.util.executor
 

Methods in com.hazelcast.util.executor with parameters of type ExecutionCallback
 void CompletableFutureTask.andThen(ExecutionCallback<V> callback)
           
 void DelegatingFuture.andThen(ExecutionCallback<V> callback)
           
 void CompletedFuture.andThen(ExecutionCallback<V> callback)
           
 void CompletableFutureTask.andThen(ExecutionCallback<V> callback, Executor executor)
           
 void DelegatingFuture.andThen(ExecutionCallback<V> callback, Executor executor)
           
 void CompletedFuture.andThen(ExecutionCallback<V> callback, Executor executor)
           
 



Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.