| Package | Description | 
|---|---|
| com.hazelcast.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.cache.impl.operation | Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.client.impl | Contains most of the client side HazelcastInstance implementation functionality. | 
| com.hazelcast.client.impl.operations | Contains client operations | 
| 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.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.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.collection.impl | |
| com.hazelcast.collection.impl.collection.operations | |
| com.hazelcast.collection.impl.list | This package contains IList functionality for Hazelcast. | 
| com.hazelcast.collection.impl.list.operations | |
| com.hazelcast.collection.impl.queue | |
| com.hazelcast.collection.impl.queue.operations | This package contains the IQueue operations | 
| com.hazelcast.collection.impl.set | This package contains ISet functionality for Hazelcast. | 
| com.hazelcast.collection.impl.set.operations | |
| com.hazelcast.collection.impl.txncollection | |
| com.hazelcast.collection.impl.txncollection.operations | |
| com.hazelcast.collection.impl.txnqueue | |
| com.hazelcast.collection.impl.txnqueue.operations | |
| com.hazelcast.concurrent.atomiclong | This package contains IAtomicLong functionality for Hazelcast. The IAtomicLong is the distributed version of the AtomicLong. | 
| com.hazelcast.concurrent.atomiclong.operations | This package contains the operations on the IAtomicLong. | 
| com.hazelcast.concurrent.atomicreference | This package contains IAtomicReferece functionality for Hazelcast. The IAtomicReference is the distributed version of the AtomicReference. | 
| com.hazelcast.concurrent.atomicreference.operations | This package contains the operations on the IAtomicReference. | 
| com.hazelcast.concurrent.countdownlatch | This package contains ICountDownLatch functionality for Hazelcast. The ICountDownLatch is the distributed version of the CountDownLatch. | 
| com.hazelcast.concurrent.countdownlatch.operations | This package contains the operations on the ICountDownLatch. | 
| com.hazelcast.concurrent.lock | |
| com.hazelcast.concurrent.lock.operations | This package contains the operations on the ILock. | 
| com.hazelcast.concurrent.semaphore | This package contains ISemaphore functionality for Hazelcast. The ISemaphore is the distributed version of the Semaphore. | 
| com.hazelcast.concurrent.semaphore.operations | This package contains the operations on the ISemaphore. | 
| com.hazelcast.durableexecutor.impl | Contains the  DurableExecutorServiceimplementation classes. | 
| com.hazelcast.durableexecutor.impl.operations | This package contains operations for the DurableExecutorService. | 
| 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.operations | This package contains operations for the IExecutorService. | 
| com.hazelcast.internal.cluster.impl | This package contains the implementation of the cluster functionality. | 
| com.hazelcast.internal.cluster.impl.operations | This package contains operations for the com.hazelcast.cluster.impl package. | 
| com.hazelcast.internal.management | Contains classes to provide data/operation interface for Management Center. | 
| com.hazelcast.internal.management.operation | Contains operations that are called from Management Center. | 
| com.hazelcast.internal.partition.operation | Contains the operations for partition package. | 
| com.hazelcast.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.operation | Package for map operations. | 
| com.hazelcast.map.impl.proxy | Contains map proxy implementation and support classes. | 
| com.hazelcast.map.impl.query | |
| com.hazelcast.map.impl.tx | Contains implementation classes for  TransactionalMap | 
| com.hazelcast.mapreduce.impl | This package contains the default implementation for the map reduce framework
 internals. | 
| com.hazelcast.mapreduce.impl.operation | This package contains all remote operations that are needed to control work on
 supervising or worker nodes. | 
| com.hazelcast.multimap.impl | Contains classes for Hazelcast MultiMap module. | 
| com.hazelcast.multimap.impl.operations | Contains operations for Hazelcast MultiMap module. | 
| com.hazelcast.multimap.impl.txn | This package contains the Transaction behavior for the Multimap. | 
| com.hazelcast.quorum.impl | Contains cluster quorum implementation classes. | 
| com.hazelcast.replicatedmap.impl | This package contains the implementation of the replicated map service itself and some connection interfaces only used
 internally. | 
| com.hazelcast.replicatedmap.impl.operation | This package contains replicated map operations which are executed on remote nodes | 
| com.hazelcast.ringbuffer.impl | Contains the  Ringbufferimplementation classes. | 
| com.hazelcast.ringbuffer.impl.operations | |
| 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.eventservice.impl.operations | Contains the operations for the  EventServiceImpl. | 
| com.hazelcast.spi.impl.operationexecutor | Contains the  OperationRunnercode. | 
| com.hazelcast.spi.impl.operationexecutor.impl | Contains the  OperationExecutorImplcode. | 
| com.hazelcast.spi.impl.operationservice | Contains the  InternalOperationServiceAPI. | 
| com.hazelcast.spi.impl.operationservice.impl | Contains the code for the  InternalOperationServiceimplementation. | 
| com.hazelcast.spi.impl.operationservice.impl.operations | Contains the Operations being used by the  OperationServiceImpl. | 
| com.hazelcast.spi.impl.operationutil | Contains utiliy classes related to  Operation | 
| com.hazelcast.spi.impl.proxyservice.impl | Contains the implementation of the  InternalProxyService. | 
| com.hazelcast.spi.impl.proxyservice.impl.operations | Contains the operations for the  ProxyServiceImpl. | 
| com.hazelcast.topic.impl | This package contains ITopic functionality for Hazelcast. With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. | 
| com.hazelcast.transaction.impl | Provides implementation for Hazelcast transaction support. | 
| com.hazelcast.transaction.impl.operations | |
| com.hazelcast.transaction.impl.xa | Provides implementation for Hazelcast XA transaction support. | 
| com.hazelcast.transaction.impl.xa.operations | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CacheOperationProvider. createContainsKeyOperation(Data key) | 
| Operation | DefaultOperationProvider. createContainsKeyOperation(Data key) | 
| Operation | CacheOperationProvider. createEntryIteratorOperation(int lastTableIndex,
                            int fetchSize) | 
| Operation | DefaultOperationProvider. createEntryIteratorOperation(int lastTableIndex,
                            int fetchSize) | 
| Operation | CacheOperationProvider. createEntryProcessorOperation(Data key,
                             Integer completionId,
                             javax.cache.processor.EntryProcessor entryProcessor,
                             Object... args) | 
| Operation | DefaultOperationProvider. createEntryProcessorOperation(Data key,
                             Integer completionId,
                             javax.cache.processor.EntryProcessor entryProcessor,
                             Object... arguments) | 
| Operation | CacheOperationProvider. createGetAndRemoveOperation(Data key,
                           int completionId) | 
| Operation | DefaultOperationProvider. createGetAndRemoveOperation(Data key,
                           int completionId) | 
| Operation | CacheOperationProvider. createGetAndReplaceOperation(Data key,
                            Data value,
                            javax.cache.expiry.ExpiryPolicy policy,
                            int completionId) | 
| Operation | DefaultOperationProvider. createGetAndReplaceOperation(Data key,
                            Data value,
                            javax.cache.expiry.ExpiryPolicy policy,
                            int completionId) | 
| Operation | CacheOperationProvider. createGetOperation(Data key,
                  javax.cache.expiry.ExpiryPolicy policy) | 
| Operation | DefaultOperationProvider. createGetOperation(Data key,
                  javax.cache.expiry.ExpiryPolicy policy) | 
| Operation | CacheOperationProvider. createKeyIteratorOperation(int lastTableIndex,
                          int fetchSize) | 
| Operation | DefaultOperationProvider. createKeyIteratorOperation(int lastTableIndex,
                          int fetchSize) | 
| Operation | CacheOperationProvider. createPutAllOperation(List<Map.Entry<Data,Data>> entries,
                     javax.cache.expiry.ExpiryPolicy policy,
                     int completionId) | 
| Operation | DefaultOperationProvider. createPutAllOperation(List<Map.Entry<Data,Data>> entries,
                     javax.cache.expiry.ExpiryPolicy policy,
                     int completionId) | 
| Operation | CacheOperationProvider. createPutIfAbsentOperation(Data key,
                          Data value,
                          javax.cache.expiry.ExpiryPolicy policy,
                          int completionId) | 
| Operation | DefaultOperationProvider. createPutIfAbsentOperation(Data key,
                          Data value,
                          javax.cache.expiry.ExpiryPolicy policy,
                          int completionId) | 
| Operation | CacheOperationProvider. createPutOperation(Data key,
                  Data value,
                  javax.cache.expiry.ExpiryPolicy policy,
                  boolean get,
                  int completionId) | 
| Operation | DefaultOperationProvider. createPutOperation(Data key,
                  Data value,
                  javax.cache.expiry.ExpiryPolicy policy,
                  boolean get,
                  int completionId) | 
| Operation | CacheOperationProvider. createRemoveOperation(Data key,
                     Data value,
                     int completionId) | 
| Operation | DefaultOperationProvider. createRemoveOperation(Data key,
                     Data oldValue,
                     int completionId) | 
| Operation | CacheOperationProvider. createReplaceOperation(Data key,
                      Data oldValue,
                      Data newValue,
                      javax.cache.expiry.ExpiryPolicy policy,
                      int completionId) | 
| Operation | DefaultOperationProvider. createReplaceOperation(Data key,
                      Data oldValue,
                      Data newValue,
                      javax.cache.expiry.ExpiryPolicy policy,
                      int completionId) | 
| Operation | AbstractCacheService. getPostJoinOperation() | 
| Operation | CacheService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMutatingCacheOperationBase class for all mutable cache operations. | 
| class  | CacheBackupEntryProcessorOperationOperation of the Cache Backup Entry Processor. | 
| class  | CacheClearBackupOperationBackup operation of  CacheClearOperation. | 
| class  | CacheClearOperationCache Clear will clear all internal cache data without sending any event | 
| class  | CacheContainsKeyOperationCache contains key operation, determines if the cache contains an entry for the specified key. | 
| class  | CacheCreateConfigOperationUsed to create cluster wide cache configuration. | 
| class  | CacheDestroyOperation
 Destroys the cache on the cluster or on a single node by calling
  ICacheService.deleteCache(String, String, boolean). | 
| class  | CacheEntryIteratorOperationProvides iterator functionality for ICache. | 
| class  | CacheEntryProcessorOperationOperation of the Cache Entry Processor. | 
| class  | CacheGetAllOperationGets all keys from the cache. | 
| class  | CacheGetAndRemoveOperationCache GetAndRemove Operation. | 
| class  | CacheGetAndReplaceOperationCache GetAndReplace Operation. | 
| class  | CacheGetConfigOperationCache GetConfig Operation. | 
| class  | CacheGetOperationCache Get Operation. | 
| class  | CacheKeyIteratorOperationProvides iterator functionality for ICache. | 
| class  | CacheListenerRegistrationOperationListener can be registered and unregistered by  CacheService. | 
| class  | CacheLoadAllOperationLoads all entries of the keys to partition record store  ICacheRecordStore. | 
| class  | CacheManagementConfigOperationCache ManagementConfig Operation provides enabling/disabling the functionality of  management and
 statistics mxbeans of the cache. | 
| class  | CacheMergeOperation | 
| class  | CachePutAllBackupOperationCache PutAllBackup Operation is the backup operation used by load all operation. | 
| class  | CachePutAllOperation | 
| class  | CachePutBackupOperationBackup operation for the operation of adding cache entries into record stores. | 
| class  | CachePutIfAbsentOperationOperation implementation for calling
  ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int). | 
| class  | CachePutOperationOperation implementation for
  ICacheRecordStore.put(Data, Object, ExpiryPolicy, String, int)andICacheRecordStore.getAndPut(Data, Object, ExpiryPolicy, String, int). | 
| class  | CacheRemoveAllBackupOperationBackup operation of  CacheRemoveAllOperation. | 
| class  | CacheRemoveAllOperationTODO add a proper JavaDoc | 
| class  | CacheRemoveBackupOperationBackup operation used by remove operations. | 
| class  | CacheRemoveOperationOperation implementation for cache remove functionality. | 
| class  | CacheReplaceOperationOperator implementation for cache replace functionality. | 
| class  | CacheReplicationOperationReplication operation is the data migration operation of  CacheRecordStore. | 
| class  | CacheSizeOperationThis operation implementation is for calculating the cluster size of a named cache. | 
| class  | PostJoinCacheOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CacheClearOperationFactory. createOperation() | 
| Operation | CacheGetAllOperationFactory. createOperation() | 
| Operation | CacheSizeOperationFactory. createOperation() | 
| Operation | CacheRemoveAllOperationFactory. createOperation() | 
| Operation | CacheLoadAllOperationFactory. createOperation() | 
| Operation | CachePutAllOperation. getBackupOperation() | 
| Operation | CacheGetAndRemoveOperation. getBackupOperation() | 
| Operation | CacheLoadAllOperation. getBackupOperation() | 
| Operation | CacheClearOperation. getBackupOperation() | 
| Operation | CacheRemoveAllOperation. getBackupOperation() | 
| Operation | CachePutOperation. getBackupOperation() | 
| Operation | CacheReplaceOperation. getBackupOperation() | 
| Operation | CacheRemoveOperation. getBackupOperation() | 
| Operation | CacheEntryProcessorOperation. getBackupOperation() | 
| Operation | CacheGetAndReplaceOperation. getBackupOperation() | 
| Operation | CachePutIfAbsentOperation. getBackupOperation() | 
| Operation | CacheMergeOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ClientEngineImpl. getPostJoinOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientDisconnectionOperation | 
| class  | ClientReAuthOperation | 
| class  | GetConnectedClientsOperation | 
| class  | PostJoinClientOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | OperationFactoryWrapper. createOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected abstract Operation | AbstractPartitionMessageTask. prepareOperation() | 
| protected abstract Operation | AbstractInvocationMessageTask. prepareOperation() | 
| protected Operation | CreateProxyMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected abstract InvocationBuilder | AbstractInvocationMessageTask. getInvocationBuilder(Operation op) | 
| protected InvocationBuilder | CreateProxyMessageTask. getInvocationBuilder(Operation op) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | AtomicLongGetAndSetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongAlterAndGetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongGetAndAddMessageTask. prepareOperation() | 
| protected Operation | AtomicLongDecrementAndGetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongApplyMessageTask. prepareOperation() | 
| protected Operation | AtomicLongAlterMessageTask. prepareOperation() | 
| protected Operation | AtomicLongAddAndGetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongCompareAndSetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongGetAndIncrementMessageTask. prepareOperation() | 
| protected Operation | AtomicLongGetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongGetAndAlterMessageTask. prepareOperation() | 
| protected Operation | AtomicLongIncrementAndGetMessageTask. prepareOperation() | 
| protected Operation | AtomicLongSetMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | AtomicReferenceCompareAndSetMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceAlterAndGetMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceContainsMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceGetAndAlterMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceSetAndGetMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceGetAndSetMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceGetMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceIsNullMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceAlterMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceSetMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceApplyMessageTask. prepareOperation() | 
| protected Operation | AtomicReferenceClearMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | CacheDestroyMessageTask. prepareOperation() | 
| protected Operation | CacheIterateMessageTask. prepareOperation() | 
| protected Operation | CacheGetMessageTask. prepareOperation() | 
| protected Operation | CacheListenerRegistrationMessageTask. prepareOperation() | 
| protected Operation | CacheEntryProcessorMessageTask. prepareOperation() | 
| protected Operation | CachePutIfAbsentMessageTask. prepareOperation() | 
| protected Operation | CacheGetAndReplaceMessageTask. prepareOperation() | 
| protected Operation | CachePutMessageTask. prepareOperation() | 
| protected Operation | CachePutAllMessageTask. prepareOperation() | 
| protected Operation | CacheRemoveMessageTask. prepareOperation() | 
| protected Operation | CacheReplaceMessageTask. prepareOperation() | 
| protected Operation | CacheContainsKeyMessageTask. prepareOperation() | 
| protected Operation | CacheCreateConfigMessageTask. prepareOperation() | 
| protected Operation | CacheGetConfigMessageTask. prepareOperation() | 
| protected Operation | CacheGetAndRemoveMessageTask. prepareOperation() | 
| protected Operation | CacheManagementConfigMessageTask. prepareOperation() | 
| protected Operation | CacheIterateEntriesMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected InvocationBuilder | CacheListenerRegistrationMessageTask. getInvocationBuilder(Operation op) | 
| protected InvocationBuilder | CacheManagementConfigMessageTask. getInvocationBuilder(Operation op) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | ConditionSignalAllMessageTask. prepareOperation() | 
| protected Operation | ConditionBeforeAwaitMessageTask. prepareOperation() | 
| protected Operation | ConditionSignalMessageTask. prepareOperation() | 
| protected Operation | ConditionAwaitMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | CountDownLatchGetCountMessageTask. prepareOperation() | 
| protected Operation | CountDownLatchAwaitMessageTask. prepareOperation() | 
| protected Operation | CountDownLatchCountDownMessageTask. prepareOperation() | 
| protected Operation | CountDownLatchTrySetCountMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | ExecutorServiceSubmitToPartitionMessageTask. prepareOperation() | 
| protected Operation | ExecutorServiceSubmitToAddressMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected InvocationBuilder | ExecutorServiceSubmitToPartitionMessageTask. getInvocationBuilder(Operation op) | 
| protected InvocationBuilder | ExecutorServiceSubmitToAddressMessageTask. getInvocationBuilder(Operation op) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | DurableExecutorRetrieveAndDisposeResultMessageTask. prepareOperation() | 
| protected Operation | DurableExecutorRetrieveResultMessageTask. prepareOperation() | 
| protected Operation | DurableExecutorSubmitToPartitionMessageTask. prepareOperation() | 
| protected Operation | DurableExecutorDisposeResultMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | ListIteratorMessageTask. prepareOperation() | 
| protected Operation | ListIndexOfMessageTask. prepareOperation() | 
| protected Operation | ListGetMessageTask. prepareOperation() | 
| protected Operation | ListLastIndexOfMessageTask. prepareOperation() | 
| protected Operation | ListAddMessageTask. prepareOperation() | 
| protected Operation | ListRemoveMessageTask. prepareOperation() | 
| protected Operation | ListListIteratorMessageTask. prepareOperation() | 
| protected Operation | ListCompareAndRetainAllMessageTask. prepareOperation() | 
| protected Operation | ListIsEmptyMessageTask. prepareOperation() | 
| protected Operation | ListCompareAndRemoveAllMessageTask. prepareOperation() | 
| protected Operation | ListSizeMessageTask. prepareOperation() | 
| protected Operation | ListContainsMessageTask. prepareOperation() | 
| protected Operation | ListAddWithIndexMessageTask. prepareOperation() | 
| protected Operation | ListSubMessageTask. prepareOperation() | 
| protected Operation | ListGetAllMessageTask. prepareOperation() | 
| protected Operation | ListRemoveWithIndexMessageTask. prepareOperation() | 
| protected Operation | ListAddAllMessageTask. prepareOperation() | 
| protected Operation | ListContainsAllMessageTask. prepareOperation() | 
| protected Operation | ListAddAllWithIndexMessageTask. prepareOperation() | 
| protected Operation | ListSetMessageTask. prepareOperation() | 
| protected Operation | ListClearMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | LockIsLockedMessageTask. prepareOperation() | 
| protected Operation | LockGetRemainingLeaseTimeMessageTask. prepareOperation() | 
| protected Operation | LockForceUnlockMessageTask. prepareOperation() | 
| protected Operation | LockIsLockedByCurrentThreadMessageTask. prepareOperation() | 
| protected Operation | LockLockMessageTask. prepareOperation() | 
| protected Operation | LockUnlockMessageTask. prepareOperation() | 
| protected Operation | LockTryLockMessageTask. prepareOperation() | 
| protected Operation | LockGetLockCountMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | MapPutAllMessageTask. prepareOperation() | 
| protected Operation | MapGetMessageTask. prepareOperation() | 
| protected Operation | MapReplaceMessageTask. prepareOperation() | 
| protected Operation | MapClearNearCacheMessageTask. prepareOperation() | 
| protected Operation | MapGetAllMessageTask. prepareOperation() | 
| protected Operation | MapTryLockMessageTask. prepareOperation() | 
| protected Operation | MapIsLockedMessageTask. prepareOperation() | 
| protected Operation | MapDeleteMessageTask. prepareOperation() | 
| protected Operation | MapLockMessageTask. prepareOperation() | 
| protected Operation | MapUnlockMessageTask. prepareOperation() | 
| protected Operation | MapPutTransientMessageTask. prepareOperation() | 
| protected Operation | MapForceUnlockMessageTask. prepareOperation() | 
| protected Operation | MapGetEntryViewMessageTask. prepareOperation() | 
| protected Operation | MapSetMessageTask. prepareOperation() | 
| protected Operation | MapFetchKeysMessageTask. prepareOperation() | 
| protected Operation | MapContainsKeyMessageTask. prepareOperation() | 
| protected Operation | MapPutIfAbsentMessageTask. prepareOperation() | 
| protected Operation | MapPutMessageTask. prepareOperation() | 
| protected Operation | MapSubmitToKeyMessageTask. prepareOperation() | 
| protected Operation | MapExecuteOnKeyMessageTask. prepareOperation() | 
| protected Operation | MapFetchEntriesMessageTask. prepareOperation() | 
| protected Operation | MapReplaceIfSameMessageTask. prepareOperation() | 
| protected Operation | MapTryPutMessageTask. prepareOperation() | 
| protected Operation | MapTryRemoveMessageTask. prepareOperation() | 
| protected Operation | MapRemoveIfSameMessageTask. prepareOperation() | 
| protected Operation | MapRemoveMessageTask. prepareOperation() | 
| protected Operation | MapEvictMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected InvocationBuilder | MapClearNearCacheMessageTask. getInvocationBuilder(Operation op) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | MultiMapForceUnlockMessageTask. prepareOperation() | 
| protected Operation | MultiMapRemoveMessageTask. prepareOperation() | 
| protected Operation | MultiMapValueCountMessageTask. prepareOperation() | 
| protected Operation | MultiMapUnlockMessageTask. prepareOperation() | 
| protected Operation | MultiMapContainsKeyMessageTask. prepareOperation() | 
| protected Operation | MultiMapGetMessageTask. prepareOperation() | 
| protected Operation | MultiMapIsLockedMessageTask. prepareOperation() | 
| protected Operation | MultiMapContainsEntryMessageTask. prepareOperation() | 
| protected Operation | MultiMapTryLockMessageTask. prepareOperation() | 
| protected Operation | MultiMapLockMessageTask. prepareOperation() | 
| protected Operation | MultiMapPutMessageTask. prepareOperation() | 
| protected Operation | MultiMapRemoveEntryMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | QueuePeekMessageTask. prepareOperation() | 
| protected Operation | QueueSizeMessageTask. prepareOperation() | 
| protected Operation | QueueOfferMessageTask. prepareOperation() | 
| protected Operation | QueueDrainMaxSizeMessageTask. prepareOperation() | 
| protected Operation | QueueIteratorMessageTask. prepareOperation() | 
| protected Operation | QueueRemainingCapacityMessageTask. prepareOperation() | 
| protected Operation | QueueIsEmptyMessageTask. prepareOperation() | 
| protected Operation | QueueContainsMessageTask. prepareOperation() | 
| protected Operation | QueuePutMessageTask. prepareOperation() | 
| protected Operation | QueueRemoveMessageTask. prepareOperation() | 
| protected Operation | QueueCompareAndRemoveAllMessageTask. prepareOperation() | 
| protected Operation | QueueAddAllMessageTask. prepareOperation() | 
| protected Operation | QueueCompareAndRetainAllMessageTask. prepareOperation() | 
| protected Operation | QueueContainsAllMessageTask. prepareOperation() | 
| protected Operation | QueueTakeMessageTask. prepareOperation() | 
| protected Operation | QueueClearMessageTask. prepareOperation() | 
| protected Operation | QueuePollMessageTask. prepareOperation() | 
| protected Operation | QueueDrainMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | ReplicatedMapPutMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapSizeMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapValuesMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapGetMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapEntrySetMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapIsEmptyMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapKeySetMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapRemoveMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapContainsValueMessageTask. prepareOperation() | 
| protected Operation | ReplicatedMapContainsKeyMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | RingbufferTailSequenceMessageTask. prepareOperation() | 
| protected Operation | RingbufferReadOneMessageTask. prepareOperation() | 
| protected Operation | RingbufferHeadSequenceMessageTask. prepareOperation() | 
| protected Operation | RingbufferRemainingCapacityMessageTask. prepareOperation() | 
| protected Operation | RingbufferAddMessageTask. prepareOperation() | 
| protected Operation | RingbufferAddAllMessageTask. prepareOperation() | 
| protected Operation | RingbufferReadManyMessageTask. prepareOperation() | 
| protected Operation | RingbufferSizeMessageTask. prepareOperation() | 
| protected Operation | RingbufferCapacityMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | SemaphoreReleaseMessageTask. prepareOperation() | 
| protected Operation | SemaphoreAcquireMessageTask. prepareOperation() | 
| protected Operation | SemaphoreReducePermitsMessageTask. prepareOperation() | 
| protected Operation | SemaphoreAvailablePermitsMessageTasks. prepareOperation() | 
| protected Operation | SemaphoreInitMessageTask. prepareOperation() | 
| protected Operation | SemaphoreDrainPermitsMessageTask. prepareOperation() | 
| protected Operation | SemaphoreTryAcquireMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | SetContainsMessageTask. prepareOperation() | 
| protected Operation | SetAddAllMessageTask. prepareOperation() | 
| protected Operation | SetGetAllMessageTask. prepareOperation() | 
| protected Operation | SetRemoveMessageTask. prepareOperation() | 
| protected Operation | SetClearMessageTask. prepareOperation() | 
| protected Operation | SetCompareAndRemoveAllMessageTask. prepareOperation() | 
| protected Operation | SetSizeMessageTask. prepareOperation() | 
| protected Operation | SetContainsAllMessageTask. prepareOperation() | 
| protected Operation | SetAddMessageTask. prepareOperation() | 
| protected Operation | SetIsEmptyMessageTask. prepareOperation() | 
| protected Operation | SetCompareAndRetainAllMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | TopicPublishMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Operation | XAFinalizeTransactionMessageTask. prepareOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<Operation> | CollectionTxnUtil. read(ObjectDataInput in) | 
| static List<Operation> | CollectionTxnUtil. run(List<Operation> operationList) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | CollectionTxnUtil. before(List<Operation> operationList,
      Operation wrapper) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | CollectionTxnUtil. after(List<Operation> operationList) | 
| static void | CollectionTxnUtil. before(List<Operation> operationList,
      Operation wrapper) | 
| static List<Operation> | CollectionTxnUtil. run(List<Operation> operationList) | 
| static void | CollectionTxnUtil. write(ObjectDataOutput out,
     List<Operation> operationList) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CollectionAddAllBackupOperation | 
| class  | CollectionAddAllOperation | 
| class  | CollectionAddBackupOperation | 
| class  | CollectionAddOperation | 
| class  | CollectionBackupAwareOperation | 
| class  | CollectionClearBackupOperation | 
| class  | CollectionClearOperation | 
| class  | CollectionCompareAndRemoveOperation | 
| class  | CollectionContainsOperation | 
| class  | CollectionGetAllOperation | 
| class  | CollectionIsEmptyOperation | 
| class  | CollectionOperation | 
| class  | CollectionRemoveBackupOperation | 
| class  | CollectionRemoveOperation | 
| class  | CollectionReplicationOperation | 
| class  | CollectionSizeOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CollectionCompareAndRemoveOperation. getBackupOperation() | 
| Operation | CollectionAddAllOperation. getBackupOperation() | 
| Operation | CollectionRemoveOperation. getBackupOperation() | 
| Operation | CollectionClearOperation. getBackupOperation() | 
| Operation | CollectionAddOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ListService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ListAddAllOperation | 
| class  | ListAddOperation | 
| class  | ListGetOperation | 
| class  | ListIndexOfOperation | 
| class  | ListRemoveOperation | 
| class  | ListReplicationOperation | 
| class  | ListSetBackupOperation | 
| class  | ListSetOperation | 
| class  | ListSubOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ListSetOperation. getBackupOperation() | 
| Operation | ListRemoveOperation. getBackupOperation() | 
| Operation | ListAddOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | QueueService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CheckAndEvictOperationProvides eviction functionality for Operations of Queue. | 
| class  | CompareAndRemoveBackupOperationThis class triggers backup method for items' id. | 
| class  | CompareAndRemoveOperationThis class triggers iterator and if find same item in the Queue, remove this item. | 
| class  | IteratorOperationProvides iterator functionality for Queue. | 
| class  | OfferBackupOperationBackup items during offer operation. | 
| class  | OfferOperationContains offer operation for the Queue. | 
| class  | PeekOperationPeek operation for Queue. | 
| class  | PollBackupOperationBackup items during pool operation. | 
| class  | PollOperationPool operation for Queue. | 
| class  | QueueBackupAwareOperationThis abstract class contains important methods for all Queue operations. | 
| class  | QueueOperationThis class contains methods for Queue operations
 such as  AddAllOperation. | 
| class  | QueueReplicationOperationReplication operation for the Queue. | 
| class  | RemainingCapacityOperationReturns the remaining capacity of the queue based on config max-size | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | PollOperation. getBackupOperation() | 
| Operation | OfferOperation. getBackupOperation() | 
| Operation | RemoveOperation. getBackupOperation() | 
| Operation | AddAllOperation. getBackupOperation() | 
| Operation | ClearOperation. getBackupOperation() | 
| Operation | CompareAndRemoveOperation. getBackupOperation() | 
| Operation | DrainOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | SetService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SetReplicationOperation | 
| Modifier and Type | Field and Description | 
|---|---|
| protected List<Operation> | CollectionTransactionLogRecord. operationList | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CollectionTransactionLogRecord. newCommitOperation() | 
| Operation | CollectionTransactionLogRecord. newPrepareOperation() | 
| Operation | CollectionTransactionLogRecord. newRollbackOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CollectionCommitBackupOperationa wrapper for running all commit backup operations at once | 
| class  | CollectionCommitOperationa wrapper for running all commit operations at once | 
| class  | CollectionPrepareBackupOperation | 
| class  | CollectionPrepareOperation | 
| class  | CollectionReserveAddOperation | 
| class  | CollectionReserveRemoveOperation | 
| class  | CollectionRollbackBackupOperation | 
| class  | CollectionRollbackOperation | 
| class  | CollectionTransactionRollbackOperation | 
| class  | CollectionTxnAddBackupOperation | 
| class  | CollectionTxnAddOperation | 
| class  | CollectionTxnRemoveBackupOperation | 
| class  | CollectionTxnRemoveOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CollectionPrepareOperation. getBackupOperation() | 
| Operation | CollectionTxnRemoveOperation. getBackupOperation() | 
| Operation | CollectionTxnAddOperation. getBackupOperation() | 
| Operation | CollectionRollbackOperation. getBackupOperation() | 
| Operation | CollectionCommitOperation. getBackupOperation() | 
| Constructor and Description | 
|---|
| CollectionCommitBackupOperation(String name,
                               String serviceName,
                               List<Operation> backupList) | 
| CollectionCommitOperation(int partitionId,
                         String name,
                         String serviceName,
                         List<Operation> operationList) | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | QueueTransactionLogRecord. newCommitOperation() | 
| Operation | QueueTransactionLogRecord. newPrepareOperation() | 
| Operation | QueueTransactionLogRecord. newRollbackOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseTxnQueueOperation | 
| class  | QueueTransactionRollbackOperationTransaction Rollback Operation for the Queue. | 
| class  | TxnOfferBackupOperationProvides backup operation during transactional offer operation. | 
| class  | TxnOfferOperationOffer operation for the Transactional Queue. | 
| class  | TxnPeekOperationPeek operation for the transactional queue. | 
| class  | TxnPollBackupOperationProvides backup operation during transactional poll operation. | 
| class  | TxnPollOperationPoll operation for the transactional queue. | 
| class  | TxnReserveOfferBackupOperationReserve offer backup operation for the transactional queue. | 
| class  | TxnReserveOfferOperationReserve offer operation for the transactional queue. | 
| class  | TxnReservePollBackupOperationReserve poll backup operation for the transactional queue. | 
| class  | TxnReservePollOperationReserve poll operation for the transactional queue. | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | TxnPrepareOperation. getBackupOperation() | 
| Operation | TxnRollbackOperation. getBackupOperation() | 
| Operation | TxnOfferOperation. getBackupOperation() | 
| Operation | TxnReserveOfferOperation. getBackupOperation() | 
| Operation | TxnCommitOperation. getBackupOperation() | 
| Operation | TxnPollOperation. getBackupOperation() | 
| Operation | TxnReservePollOperation. getBackupOperation() | 
| Constructor and Description | 
|---|
| TxnCommitBackupOperation(String name,
                        List<Operation> backupList) | 
| TxnCommitOperation(int partitionId,
                  String name,
                  List<Operation> operationList) | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | AtomicLongService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAlterOperation | 
| class  | AbstractAtomicLongOperation | 
| class  | AddAndGetOperation | 
| class  | AddBackupOperation | 
| class  | AlterAndGetOperation | 
| class  | AlterOperation | 
| class  | ApplyOperation<R> | 
| class  | AtomicLongBackupAwareOperation | 
| class  | AtomicLongReplicationOperation | 
| class  | CompareAndSetOperation | 
| class  | GetAndAddOperation | 
| class  | GetAndAlterOperation | 
| class  | GetAndSetOperation | 
| class  | SetBackupOperation | 
| class  | SetOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | SetOperation. getBackupOperation() | 
| Operation | GetAndSetOperation. getBackupOperation() | 
| Operation | AbstractAlterOperation. getBackupOperation() | 
| Operation | CompareAndSetOperation. getBackupOperation() | 
| Operation | AddAndGetOperation. getBackupOperation() | 
| Operation | GetAndAddOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | AtomicReferenceService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAtomicReferenceOperation | 
| class  | AtomicReferenceBackupAwareOperation | 
| class  | AtomicReferenceReplicationOperation | 
| class  | ContainsOperation | 
| class  | IsNullOperation | 
| class  | SetAndGetOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | SetOperation. getBackupOperation() | 
| Operation | GetAndSetOperation. getBackupOperation() | 
| Operation | AbstractAlterOperation. getBackupOperation() | 
| Operation | SetAndGetOperation. getBackupOperation() | 
| Operation | CompareAndSetOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CountDownLatchService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CountDownLatchBackupOperation | 
| class  | CountDownLatchReplicationOperation | 
| class  | CountDownOperation | 
| class  | GetCountOperation | 
| class  | SetCountOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | LockServiceImpl. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractLockOperation | 
| class  | AwaitBackupOperation | 
| class  | AwaitOperation | 
| class  | BeforeAwaitBackupOperation | 
| class  | BeforeAwaitOperation | 
| class  | GetLockCountOperation | 
| class  | GetRemainingLeaseTimeOperation | 
| class  | IsLockedOperation | 
| class  | LocalLockCleanupOperation | 
| class  | LockBackupOperation | 
| class  | LockOperation | 
| class  | LockReplicationOperation | 
| class  | SignalBackupOperation | 
| class  | SignalOperation | 
| class  | UnlockBackupOperation | 
| class  | UnlockIfLeaseExpiredOperation | 
| class  | UnlockOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | LockOperation. getBackupOperation() | 
| Operation | BeforeAwaitOperation. getBackupOperation() | 
| Operation | UnlockOperation. getBackupOperation() | 
| Operation | SignalOperation. getBackupOperation() | 
| Operation | AwaitOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | SemaphoreService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AcquireBackupOperation | 
| class  | AcquireOperation | 
| class  | AvailableOperation | 
| class  | DrainBackupOperation | 
| class  | DrainOperation | 
| class  | InitBackupOperation | 
| class  | InitOperation | 
| class  | ReduceBackupOperation | 
| class  | ReduceOperation | 
| class  | ReleaseBackupOperation | 
| class  | ReleaseOperation | 
| class  | SemaphoreBackupAwareOperation | 
| class  | SemaphoreBackupOperation | 
| class  | SemaphoreDetachMemberBackupOperation | 
| class  | SemaphoreDetachMemberOperation | 
| class  | SemaphoreOperation | 
| class  | SemaphoreReplicationOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | InitOperation. getBackupOperation() | 
| Operation | SemaphoreDetachMemberOperation. getBackupOperation() | 
| Operation | ReleaseOperation. getBackupOperation() | 
| Operation | ReduceOperation. getBackupOperation() | 
| Operation | AcquireOperation. getBackupOperation() | 
| Operation | DrainOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | DurableExecutorPartitionContainer. prepareReplicationOperation(int replicaIndex) | 
| Operation | DistributedDurableExecutorService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DisposeResultOperation | 
| class  | PutResultOperation | 
| class  | ReplicationOperation | 
| class  | RetrieveAndDisposeResultOperation | 
| class  | RetrieveResultOperationUsed to retrieve the response of an execution with the given sequence | 
| class  | ShutdownOperation | 
| class  | TaskBackupOperation | 
| class  | TaskOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | DisposeResultOperation. getBackupOperation() | 
| Operation | TaskOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DistributedExecutorService. execute(String name,
       String uuid,
       Callable callable,
       Operation op) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CallableTaskOperation | 
| class  | CancellationOperation | 
| class  | MemberCallableTaskOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ClusterStateTransactionLogRecord. newCommitOperation() | 
| Operation | ClusterStateTransactionLogRecord. newPrepareOperation() | 
| Operation | ClusterStateTransactionLogRecord. newRollbackOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AuthenticationFailureOperation | 
| class  | AuthorizationOperation | 
| class  | BeforeJoinCheckFailureOperation | 
| class  | ChangeClusterStateOperation | 
| class  | ConfigMismatchOperationWhen a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated. | 
| class  | FinalizeJoinOperation | 
| class  | GroupMismatchOperation | 
| class  | HeartbeatOperation | 
| class  | JoinCheckOperation | 
| class  | JoinRequestOperation | 
| class  | LockClusterStateOperation | 
| class  | MasterClaimOperation | 
| class  | MasterConfirmationOperation | 
| class  | MasterDiscoveryOperation | 
| class  | MemberAttributeChangedOperation | 
| class  | MemberInfoUpdateOperation | 
| class  | MemberRemoveOperation | 
| class  | MergeClustersOperation | 
| class  | PostJoinOperation | 
| class  | RollbackClusterStateOperation | 
| class  | SetMasterOperation | 
| class  | ShutdownNodeOperation | 
| class  | TriggerMemberListPublishOperationRequests member list publish from master node | 
| Constructor and Description | 
|---|
| PostJoinOperation(Operation... ops) | 
| Modifier and Type | Method and Description | 
|---|---|
| Object | ManagementCenterService. callOnAddress(Address address,
             Operation operation) | 
| Object | ManagementCenterService. callOnMember(Member member,
            Operation operation) | 
| Object | ManagementCenterService. callOnThis(Operation operation) | 
| void | ManagementCenterService. send(Address address,
    Operation operation) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ChangeWanStateOperationEnables/Disable publishing events to target cluster in WAN Replication  WanReplicationServiceon a node. | 
| class  | GetMapConfigOperationOperation to fetch Map configuration. | 
| class  | ScriptExecutorOperationOperation to execute script on the node. | 
| class  | ThreadDumpOperationOperation for generating thread dumps. | 
| class  | UpdateManagementCenterUrlOperationOperation to update Management Center URL configured on the node. | 
| class  | UpdateMapConfigOperationOperation to update map configuration from Management Center. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AssignPartitions | 
| class  | CheckReplicaVersion | 
| class  | FetchPartitionStateOperation | 
| class  | FinalizeMigrationOperation | 
| class  | HasOngoingMigration | 
| class  | MigrationCommitOperationUsed for committing a migration on migration destination. | 
| class  | MigrationOperation | 
| class  | MigrationRequestOperation | 
| class  | PartitionStateOperation | 
| class  | PromotionCommitOperationUsed for committing a promotion on destination. | 
| class  | ReplicaSyncRequest | 
| class  | ReplicaSyncResponse | 
| class  | ReplicaSyncRetryResponse | 
| class  | SafeStateCheckOperationChecks whether a node is safe or not. | 
| class  | ShutdownRequestOperation | 
| class  | ShutdownResponseOperation | 
| Constructor and Description | 
|---|
| MigrationOperation(MigrationInfo migrationInfo,
                  long[] replicaVersions,
                  Collection<Operation> tasks,
                  int partitionStateVersion) | 
| ReplicaSyncResponse(List<Operation> data,
                   long[] replicaVersions) | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | MapService. getPostJoinOperation() | 
| Operation | MapService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MapServiceContext. incrementOperationStats(long startTime,
                       LocalMapStatsImpl localMapStats,
                       String mapName,
                       Operation operation) | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ContainsValueOperationFactory. createOperation() | 
| Operation | PartitionCheckIfLoadedOperationFactory. createOperation() | 
| Operation | MapLoadAllOperationFactory. createOperation() | 
| Operation | LoadStatusOperationFactory. createOperation() | 
| Operation | RemoveInterceptorOperationFactory. createOperation() | 
| Operation | PartitionWideEntryOperationFactory. createOperation() | 
| Operation | MapFlushOperationFactory. createOperation() | 
| Operation | MultipleEntryOperationFactory. createOperation() | 
| Operation | EvictAllOperationFactory. createOperation() | 
| Operation | SizeOperationFactory. createOperation() | 
| Operation | ClearOperationFactory. createOperation() | 
| Operation | AddIndexOperationFactory. createOperation() | 
| Operation | IsEmptyOperationFactory. createOperation() | 
| Operation | MapGetAllOperationFactory. createOperation() | 
| Operation | AddInterceptorOperationFactory. createOperation() | 
| Operation | PutAllPartitionAwareOperationFactory. createPartitionOperation(int partitionId) | 
| Operation | PartitionWideEntryWithPredicateOperationFactory. createPartitionOperation(int partition) | 
| Operation | MultipleEntryOperation. getBackupOperation() | 
| Operation | EvictAllOperation. getBackupOperation() | 
| Operation | BasePutOperation. getBackupOperation() | 
| Operation | PartitionWideEntryWithPredicateOperation. getBackupOperation() | 
| Operation | PartitionWideEntryOperation. getBackupOperation() | 
| Operation | MapFlushOperation. getBackupOperation() | 
| Operation | EntryOperation. getBackupOperation() | 
| Operation | MergeOperation. getBackupOperation() | 
| Operation | ClearOperation. getBackupOperation() | 
| Operation | MultipleEntryWithPredicateOperation. getBackupOperation() | 
| Operation | BaseRemoveOperation. getBackupOperation() | 
| Operation | PutAllOperation. getBackupOperation() | 
| Operation | EvictOperation. getBackupOperation() | 
| Operation | PutFromLoadAllOperation. getBackupOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Object | MapProxyImpl. invoke(Operation operation,
      int partitionId) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueryOperation | 
| class  | QueryPartitionOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TxnDeleteOperationTransactional delete operation | 
| class  | TxnLockAndGetOperationTransactional lock and get operation. | 
| class  | TxnPrepareBackupOperationAn operation to prepare transaction by locking the key on key backup owner. | 
| class  | TxnPrepareOperationAn operation to prepare transaction by locking the key on the key owner. | 
| class  | TxnRollbackBackupOperationAn operation to rollback transaction by unlocking the key on key backup owner. | 
| class  | TxnRollbackOperationAn operation to rollback transaction by unlocking the key on key owner. | 
| class  | TxnSetOperationAn operation to unlock and set (key,value) on the partition . | 
| class  | TxnUnlockBackupOperationAn operation to unlock key on the backup owner. | 
| class  | TxnUnlockOperationAn operation to unlock key on the partition owner. | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | TxnPrepareOperation. getBackupOperation() | 
| Operation | TxnSetOperation. getBackupOperation() | 
| Operation | TxnRollbackOperation. getBackupOperation() | 
| Operation | TxnUnlockOperation. getBackupOperation() | 
| Operation | TxnDeleteOperation. getBackupOperation() | 
| Operation | MapTransactionLogRecord. newCommitOperation() | 
| Operation | MapTransactionLogRecord. newPrepareOperation() | 
| Operation | MapTransactionLogRecord. newRollbackOperation() | 
| Constructor and Description | 
|---|
| MapTransactionLogRecord(String name,
                       Data key,
                       int partitionId,
                       Operation op,
                       long version,
                       String ownerUuid) | 
| Modifier and Type | Method and Description | 
|---|---|
| static <V> V | MapReduceUtil. executeOperation(Operation operation,
                Address address,
                MapReduceService mapReduceService,
                NodeEngine nodeEngine) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CancelJobSupervisorOperationThis operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes. | 
| class  | FireNotificationOperationThis operation is used to transport and execute a notification on a remote node since
 the current event service is not capable of reliable transmission so this is a fallback
 to sync operations which is hopefully only a temporary workaround! | 
| class  | GetResultOperationThis operation is used to retrieve results from a remote node | 
| class  | KeysAssignmentOperationThis operation is used to request assignment for keys on the job owners node. | 
| class  | KeyValueJobOperation<K,V>This operation is used to prepare a  KeyValueSourcebased
 map reduce operation on all cluster members. | 
| class  | NotifyRemoteExceptionOperationThis operation is used to inform the job owner of a remote exception | 
| class  | PostPonePartitionProcessingThis operation is used to tell the job owner to postpone a mapping phase for the defined
 partitionId. | 
| class  | ProcessingOperationThis is the base class for all map reduce framework operations, it always contains the name of
 the JobTracker and the unique jobId | 
| class  | ProcessStatsUpdateOperationThis operation is used to update the process statistics on the owner node | 
| class  | RequestMemberIdAssignmentThis operation is used to do some kind of partitionId based processing on non partition based implementations
 of  KeyValueSource(not implementingPartitionIdAware)
 which can happen for custom data sources like distributed filesystems that are up to the end user on how to
 manage the distribution. | 
| class  | RequestPartitionMappingThis operation requests a new partition to process by the requester on the job owning node | 
| class  | RequestPartitionProcessedThis operation tells the job owner to mark a partition as fully processed | 
| class  | RequestPartitionReducingThis operation tells the job owner to start reducing phase of the defined partition on the first
 occurrence of a full emitted chunk | 
| class  | StartProcessingJobOperation<K>This operation is used to start the actual processing after all node prepared to execute the map reduce job | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | GetResultOperationFactory. createOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | MultiMapService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ContainsEntryOperation | 
| class  | CountOperation | 
| class  | MultiMapBackupAwareOperation | 
| class  | MultiMapKeyBasedOperation | 
| class  | MultiMapMigrationOperation | 
| class  | MultiMapOperation | 
| class  | RemoveAllBackupOperation | 
| class  | RemoveAllOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | MultiMapOperationFactory. createOperation() | 
| Operation | RemoveAllOperation. getBackupOperation() | 
| Operation | RemoveOperation. getBackupOperation() | 
| Operation | ClearOperation. getBackupOperation() | 
| Operation | PutOperation. getBackupOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TxnCommitBackupOperation | 
| class  | TxnCommitOperation | 
| class  | TxnGenerateRecordIdOperation | 
| class  | TxnPutBackupOperation | 
| class  | TxnPutOperation | 
| class  | TxnRemoveAllBackupOperation | 
| class  | TxnRemoveAllOperation | 
| class  | TxnRemoveBackupOperation | 
| class  | TxnRemoveOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | TxnPrepareOperation. getBackupOperation() | 
| Operation | TxnRollbackOperation. getBackupOperation() | 
| Operation | TxnPutOperation. getBackupOperation() | 
| Operation | TxnRemoveOperation. getBackupOperation() | 
| Operation | TxnCommitOperation. getBackupOperation() | 
| Operation | TxnRemoveAllOperation. getBackupOperation() | 
| Operation | MultiMapTransactionLogRecord. newCommitOperation() | 
| Operation | MultiMapTransactionLogRecord. newPrepareOperation() | 
| Operation | MultiMapTransactionLogRecord. newRollbackOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MultiMapTransactionLogRecord. addOperation(Operation op) | 
| Constructor and Description | 
|---|
| TxnCommitBackupOperation(String name,
                        Data dataKey,
                        List<Operation> opList,
                        String caller,
                        long threadId) | 
| TxnCommitOperation(int partitionId,
                  String name,
                  Data dataKey,
                  long threadId,
                  List<Operation> opList) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QuorumImpl. ensureQuorumPresent(Operation op) | 
| void | QuorumServiceImpl. ensureQuorumPresent(Operation op) | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ReplicatedMapService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractReplicatedMapOperation | 
| class  | ClearOperationThis operation will execute the remote clear on replicated map if
  ReplicatedMap.clear()is called. | 
| class  | ContainsKeyOperation | 
| class  | ContainsValueOperation | 
| class  | EntrySetOperation | 
| class  | EvictionOperationEvicts set of entries from the record store. | 
| class  | GetOperation | 
| class  | IsEmptyOperation | 
| class  | KeySetOperation | 
| class  | PutAllOperationPuts a set of records to the replicated map. | 
| class  | ReplicateUpdateOperationReplicates the update happened on the partition owner to the other nodes. | 
| class  | ReplicateUpdateToCallerOperationThis operation will update the local record store with the update received from local/remote partition owner. | 
| class  | RequestMapDataOperationCollects and sends the replicated map data from the executing node to the caller via
  SyncReplicatedMapDataOperation. | 
| class  | SizeOperation | 
| class  | SyncReplicatedMapDataOperation<K,V>Carries set of replicated map records for a partition from one node to another | 
| class  | ValuesOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ClearOperationFactory. createOperation() | 
| Operation | PutAllOperationFactory. createOperation() | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | RingbufferService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractRingBufferOperation | 
| class  | AddAllBackupOperation | 
| class  | AddAllOperation | 
| class  | AddOperation | 
| class  | GenericOperation | 
| class  | ReadManyOperation | 
| class  | ReadOneOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | AddOperation. getBackupOperation() | 
| Operation | AddAllOperation. getBackupOperation() | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | OperationResponseHandler<O extends Operation>A handler for the  OperationServicewhen it has calculated a response. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractOperationDeprecated. 
 since 3.7. Use  Operationdirectly. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Operation | InvocationBuilder. op | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | OperationFactory. createOperation()Creates the operation. | 
| Operation | BackupAwareOperation. getBackupOperation()Creates the  BackupOperationresponsible for making the backup. | 
| Operation | InvocationBuilder. getOp()Gets the operation to execute. | 
| Operation | PostJoinAwareService. getPostJoinOperation()Post join operations must be lock free, meaning no locks at all:
 no partition locks, no key-based locks, no service level locks,
 no database interaction! | 
| Operation | MigrationAwareService. prepareReplicationOperation(PartitionReplicationEvent event)Returns an operation to replicate service data and/or state for a specific partition replica
 on another cluster member. | 
| Operation | Operation. setCallerUuid(String callerUuid) | 
| Operation | Operation. setNodeEngine(NodeEngine nodeEngine) | 
| Operation | Operation. setOperationResponseHandler(OperationResponseHandler responseHandler)Sets the OperationResponseHandler. | 
| Operation | Operation. setPartitionId(int partitionId)Sets the partition id. | 
| Operation | Operation. setReplicaIndex(int replicaIndex) | 
| Operation | Operation. setService(Object service) | 
| Operation | Operation. setServiceName(String serviceName) | 
| Operation | Operation. setValidateTarget(boolean validateTarget) | 
| Modifier and Type | Method and Description | 
|---|---|
| InvocationBuilder | OperationService. createInvocationBuilder(String serviceName,
                       Operation op,
                       Address target) | 
| InvocationBuilder | OperationService. createInvocationBuilder(String serviceName,
                       Operation op,
                       int partitionId) | 
| void | OperationService. execute(Operation op)Executes an operation in the operation executor pool. | 
| void | OperationService. executeOperation(Operation op)Deprecated. 
 since 3.7. Use  OperationService.execute(Operation). | 
| <E> InternalCompletableFuture<E> | OperationService. invokeOnPartition(Operation op)Executes an operation on a partition. | 
| protected <E> InternalCompletableFuture<E> | AbstractDistributedObject. invokeOnPartition(Operation operation) | 
| <E> InternalCompletableFuture<E> | OperationService. invokeOnPartition(String serviceName,
                 Operation op,
                 int partitionId) | 
| <E> InternalCompletableFuture<E> | OperationService. invokeOnTarget(String serviceName,
              Operation op,
              Address target) | 
| void | OperationService. run(Operation op)Runs an operation in the calling thread. | 
| void | OperationService. runOperationOnCallingThread(Operation op)Deprecated. 
 since 3.7. Use  OperationService.run(Operation) | 
| boolean | OperationService. send(Operation op,
    Address target)Executes an operation remotely. | 
| static void | OperationAccessor. setCallerAddress(Operation op,
                Address caller) | 
| static void | OperationAccessor. setCallId(Operation op,
         long callId)Sets the callId for the Operation. | 
| static void | OperationAccessor. setCallTimeout(Operation op,
              long callTimeout)Sets the call timeout in milliseconds for the Operation. | 
| static void | OperationAccessor. setConnection(Operation op,
             Connection connection) | 
| static void | OperationAccessor. setInvocationTime(Operation op,
                 long invocationTime)Sets the invocation time for the Operation. | 
| Constructor and Description | 
|---|
| InvocationBuilder(String serviceName,
                 Operation op,
                 int partitionId,
                 Address target)Creates an InvocationBuilder | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractNamedOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | BinaryOperationFactory. createOperation() | 
| Operation[] | NodeEngineImpl. getPostJoinOperations()Post join operations must be lock free; means no locks at all;
 no partition locks, no key-based locks, no service level locks!
 
 Post join operations should return response, at least a null response. | 
| Operation | DelegatingMigrationAwareService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Constructor and Description | 
|---|
| BinaryOperationFactory(Operation operation,
                      NodeEngine nodeEngine) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DeregistrationOperation | 
| class  | PostJoinRegistrationOperation | 
| class  | RegistrationOperation | 
| class  | SendEventOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| void | OperationExecutor. execute(Operation op)Executes the given  Operationat some point in the future. | 
| boolean | OperationExecutor. isInvocationAllowed(Operation op,
                   boolean isAsync)Checks if the  Operationis allowed to be invoked from the current thread. | 
| boolean | OperationExecutor. isRunAllowed(Operation op)Checks if the  Operationis allowed to run on the current thread. | 
| abstract void | OperationRunner. run(Operation task) | 
| void | OperationExecutor. run(Operation op)Runs the  Operationon the calling thread. | 
| void | OperationExecutor. runOrExecute(Operation op)Tries to run the  Operationon the calling thread if allowed. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | OperationExecutorImpl. execute(Operation op) | 
| boolean | OperationExecutorImpl. isInvocationAllowed(Operation op,
                   boolean isAsync) | 
| boolean | OperationExecutorImpl. isRunAllowed(Operation op) | 
| void | OperationExecutorImpl. run(Operation operation) | 
| void | OperationExecutorImpl. runOrExecute(Operation op) | 
| Modifier and Type | Method and Description | 
|---|---|
| <V> void | InternalOperationService. asyncInvokeOnPartition(String serviceName,
                      Operation op,
                      int partitionId,
                      ExecutionCallback<V> callback) | 
| boolean | InternalOperationService. isCallTimedOut(Operation op)Checks if this call is timed out. | 
| boolean | InternalOperationService. isRunAllowed(Operation op)Returns true if the given operation is allowed to run on the calling thread, false otherwise. | 
| Modifier and Type | Field and Description | 
|---|---|
| Operation | Invocation. opThe  Operationthis invocation is evaluating. | 
| Modifier and Type | Method and Description | 
|---|---|
| <V> void | OperationServiceImpl. asyncInvokeOnPartition(String serviceName,
                      Operation op,
                      int partitionId,
                      ExecutionCallback<V> callback) | 
| InvocationBuilder | OperationServiceImpl. createInvocationBuilder(String serviceName,
                       Operation op,
                       Address target) | 
| InvocationBuilder | OperationServiceImpl. createInvocationBuilder(String serviceName,
                       Operation op,
                       int partitionId) | 
| void | OperationServiceImpl. execute(Operation op) | 
| void | OperationServiceImpl. executeOperation(Operation op) | 
| <E> InternalCompletableFuture<E> | OperationServiceImpl. invokeOnPartition(Operation op) | 
| <E> InternalCompletableFuture<E> | OperationServiceImpl. invokeOnPartition(String serviceName,
                 Operation op,
                 int partitionId) | 
| <E> InternalCompletableFuture<E> | OperationServiceImpl. invokeOnTarget(String serviceName,
              Operation op,
              Address target) | 
| boolean | OperationServiceImpl. isCallTimedOut(Operation op) | 
| boolean | OperationServiceImpl. isRunAllowed(Operation op) | 
| void | OperationServiceImpl. run(Operation op) | 
| void | OperationServiceImpl. runOperationOnCallingThread(Operation op) | 
| boolean | OperationServiceImpl. send(Operation op,
    Address target) | 
| void | Invocation. sendResponse(Operation op,
            Object response) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | Backup | 
| class  | PartitionIteratingOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | PartitionAwareOperationFactory. createOperation() | 
| abstract Operation | PartitionAwareOperationFactory. createPartitionOperation(int partition)This method can be called both caller and runner nodes. | 
| Operation | Backup. getBackupOp() | 
| Constructor and Description | 
|---|
| Backup(Operation backupOp,
      Address originalCaller,
      long[] replicaVersions,
      boolean sync) | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | Operations. isJoinOperation(Operation op) | 
| static boolean | Operations. isMigrationOperation(Operation op) | 
| static boolean | Operations. isWanReplicationOperation(Operation op)Checks if the given operation is an instance of  WanReplicationOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | ProxyServiceImpl. getPostJoinOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DistributedObjectDestroyOperation | 
| class  | InitializeDistributedObjectOperation | 
| class  | PostJoinProxyOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PublishOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | TransactionLogRecord. newCommitOperation() | 
| Operation | TransactionLogRecord. newPrepareOperation() | 
| Operation | TransactionLogRecord. newRollbackOperation() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractTxOperation | 
| class  | BroadcastTxRollbackOperation | 
| class  | CreateAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | CreateTxBackupLogOperation | 
| class  | PurgeAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | PurgeTxBackupLogOperation | 
| class  | ReplicateAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | ReplicateTxBackupLogOperationReplicates the transactionlog to a remote system. | 
| class  | RollbackAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | RollbackTxBackupLogOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | XAService. prepareReplicationOperation(PartitionReplicationEvent event) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractXAOperation | 
| class  | ClearRemoteTransactionBackupOperation | 
| class  | ClearRemoteTransactionOperation | 
| class  | CollectRemoteTransactionsOperation | 
| class  | FinalizeRemoteTransactionBackupOperation | 
| class  | FinalizeRemoteTransactionOperation | 
| class  | PutRemoteTransactionBackupOperation | 
| class  | PutRemoteTransactionOperation | 
| class  | XaReplicationOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| Operation | CollectRemoteTransactionsOperationFactory. createOperation() | 
| Operation | FinalizeRemoteTransactionOperation. getBackupOperation() | 
| Operation | ClearRemoteTransactionOperation. getBackupOperation() | 
| Operation | PutRemoteTransactionOperation. getBackupOperation() | 
Copyright © 2017 Hazelcast, Inc.. All Rights Reserved.