| Package | Description | 
|---|---|
| com.hazelcast.cache.impl.journal | |
| com.hazelcast.cache.impl.operation | Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.collection.impl.queue.operations | This package contains the IQueue operations | 
| com.hazelcast.collection.impl.txnqueue.operations | |
| com.hazelcast.concurrent.countdownlatch.operations | This package contains the operations on the ICountDownLatch. | 
| com.hazelcast.concurrent.semaphore.operations | This package contains the operations on the ISemaphore. | 
| com.hazelcast.durableexecutor.impl.operations | This package contains operations for the DurableExecutorService. | 
| com.hazelcast.map.impl.journal | |
| com.hazelcast.map.impl.operation | Package for map operations. | 
| com.hazelcast.map.impl.query | |
| com.hazelcast.map.impl.querycache.subscriber.operation | This package contains Enterprise specific operations for  QueryCache. | 
| com.hazelcast.map.impl.tx | Contains implementation classes for  TransactionalMap | 
| 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. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CacheEventJournalSubscribeOperationPerforms the initial subscription to the cache event journal. | 
| Modifier and Type | Class and Description | 
|---|---|
| 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  | CacheCreateConfigOperationDeprecated. 
 as of 3.10 replaced by  AddCacheConfigOperation, which is used in conjunction withInvocationUtil.invokeOnStableClusterSerial(NodeEngine,
 com.hazelcast.util.function.Supplier, int)to reliably broadcast theCacheConfigto all members of the cluster. | 
| 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  | CacheExpireBatchBackupOperationUsed to transfer expired keys from owner replica to backup replicas. | 
| class  | CacheGetAllOperationGets all keys from the cache. | 
| class  | CacheGetAndRemoveOperationCache GetAndRemove Operation. | 
| class  | CacheGetAndReplaceOperationCache GetAndReplace Operation. | 
| class  | CacheGetConfigOperationGets a cache configuration or creates one, if a matching cache config is found in this member's config. | 
| class  | CacheGetOperationCache Get Operation. | 
| class  | CacheKeyIteratorOperationProvides iterator functionality for ICache. | 
| class  | CacheLegacyMergeOperationContains a merging entry for split-brain healing with a  CacheMergePolicy. | 
| 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  | CacheMergeOperationContains multiple merging entries for split-brain healing with a  SplitBrainMergePolicy. | 
| class  | CacheOperationBase Cache Operation. | 
| 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  | CacheSetExpiryPolicyBackupOperation | 
| class  | CacheSetExpiryPolicyOperation | 
| class  | CacheSizeOperationThis operation implementation is for calculating the cluster size of a named cache. | 
| class  | KeyBasedCacheOperationOperations running on a single key should extend this class. | 
| class  | MutatingCacheOperationBase class for all mutable cache operations. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddAllBackupOperationProvides backup functionality for  AddAllOperation | 
| class  | AddAllOperationAdd collection items to the Queue. | 
| 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  | ContainsOperationChecks whether contain or not item in the Queue. | 
| class  | DrainBackupOperationThis class stores items' ID when DrainOperation run. | 
| class  | DrainOperationThis class drain items according to drain condition. | 
| class  | IsEmptyOperationcheck if queue is empty | 
| 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  | QueueMergeBackupOperationCreates backups for merged queue items after split-brain healing with a  SplitBrainMergePolicy. | 
| class  | QueueMergeOperationMerges a  SplitBrainMergeTypes.QueueMergeTypesfor split-brain healing with aSplitBrainMergePolicy. | 
| class  | QueueOperationThis class contains methods for Queue operations
 such as  AddAllOperation. | 
| class  | RemainingCapacityOperationReturns the remaining capacity of the queue based on config max-size | 
| class  | SizeOperationNotify size of the queue. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseTxnQueueOperation | 
| class  | QueueTransactionRollbackOperationTransaction Rollback Operation for the Queue. | 
| class  | TxnCommitBackupOperationa wrapper for running all commit backup operations at once | 
| class  | TxnCommitOperationa wrapper for running all commit operations at once | 
| class  | TxnOfferBackupOperationProvides backup operation during transactional offer operation. | 
| class  | TxnOfferOperationTransaction commit operation for a queue offer, executed on the primary replica. | 
| class  | TxnPeekOperationPeek operation for the transactional queue. | 
| class  | TxnPollBackupOperationProvides backup operation during transactional poll operation. | 
| class  | TxnPollOperationPoll operation for the transactional queue. | 
| class  | TxnReserveOfferBackupOperationTransaction prepare operation for a queue offer, executed on the backup replica. | 
| class  | TxnReserveOfferOperationTransaction prepare operation for a queue offer, executed on the primary replica. | 
| class  | TxnReservePollBackupOperationTransaction prepare operation for a queue poll, executed on the backup replica. | 
| class  | TxnReservePollOperationTransaction prepare operation for a queue poll, executed on the primary replica. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AwaitOperation | 
| class  | CountDownLatchBackupOperation | 
| class  | CountDownOperation | 
| class  | GetCountOperation | 
| class  | SetCountOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AcquireBackupOperation | 
| class  | AcquireOperation | 
| class  | AvailableOperation | 
| class  | IncreaseBackupOperation | 
| class  | IncreaseOperation | 
| class  | InitBackupOperation | 
| class  | InitOperation | 
| class  | ReduceBackupOperation | 
| class  | ReduceOperation | 
| class  | ReleaseBackupOperation | 
| class  | ReleaseOperation | 
| class  | SemaphoreBackupAwareOperation | 
| class  | SemaphoreBackupOperation | 
| class  | SemaphoreDetachMemberBackupOperation | 
| class  | SemaphoreDetachMemberOperation | 
| class  | SemaphoreOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DisposeResultBackupOperation | 
| class  | DisposeResultOperation | 
| class  | PutResultBackupOperation | 
| class  | PutResultOperation | 
| class  | RetrieveAndDisposeResultOperation | 
| class  | RetrieveResultOperationUsed to retrieve the response of an execution with the given sequence | 
| class  | ShutdownOperation | 
| class  | TaskBackupOperation | 
| class  | TaskOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapEventJournalSubscribeOperationPerforms the initial subscription to the map event journal. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddIndexBackupOperation | 
| class  | AddIndexOperation | 
| class  | AwaitMapFlushOperationIMap.flush()call waits the end of flush by using this operation. | 
| class  | BasePutOperation | 
| class  | BaseRemoveOperation | 
| class  | ClearBackupOperation | 
| class  | ClearNearCacheOperationDeprecated.  | 
| class  | ClearOperation | 
| class  | ContainsKeyOperation | 
| class  | ContainsValueOperation | 
| class  | DeleteOperation | 
| class  | EntryBackupOperation | 
| class  | EntryOffloadableSetUnlockOperationSet & Unlock processing for the EntryOperation
 See the javadoc on  EntryOperation | 
| class  | EntryOperationContains implementation of the off-loadable contract for EntryProcessor execution on a single key. | 
| class  | EvictAllBackupOperationOperation which evicts all keys except locked ones. | 
| class  | EvictAllOperationOperation which evicts all keys except locked ones. | 
| class  | EvictBackupOperation | 
| class  | EvictBatchBackupOperationUsed to transfer expired keys from owner replica to backup replicas. | 
| class  | EvictOperation | 
| class  | GetAllOperation | 
| class  | GetEntryViewOperation | 
| class  | GetOperation | 
| class  | IsKeyLoadFinishedOperationReturns if the key loading and dispatching has finished on this partition | 
| class  | IsPartitionLoadedOperation | 
| class  | KeyBasedMapOperation | 
| class  | KeyLoadStatusOperationNotifies record store about completion of key loading. | 
| class  | LegacyMergeOperationContains a merging entry for split-brain healing with a  MapMergePolicy. | 
| class  | LoadAllOperationTriggers loading values for the given keys from the defined
  MapLoader. | 
| class  | LoadMapOperationTriggers map loading from a map store. | 
| class  | LockAwareOperation | 
| class  | MapFetchEntriesOperationOperation for fetching a chunk of entries from a single  IMappartition. | 
| class  | MapFetchKeysOperationOperation for fetching a chunk of keys from a single  IMappartition. | 
| class  | MapFetchWithQueryOperationFetches by query a batch of  fetchSizeitems from a single partition ID for a map. | 
| class  | MapFlushBackupOperationEmpties backup write-behind-queues upon  IMap.flush() | 
| class  | MapFlushOperationFlushes dirty entries upon call of  IMap.flush() | 
| class  | MapIsEmptyOperation | 
| class  | MapOperation | 
| class  | MapSizeOperation | 
| class  | MergeOperationContains multiple merge entries for split-brain healing with a  SplitBrainMergePolicy. | 
| class  | MultipleEntryBackupOperation | 
| class  | MultipleEntryOperation | 
| class  | MultipleEntryWithPredicateBackupOperation | 
| class  | MultipleEntryWithPredicateOperation | 
| class  | NotifyMapFlushOperation | 
| class  | PartitionWideEntryBackupOperation | 
| class  | PartitionWideEntryOperationGOTCHA: This operation does NOT load missing keys from map-store for now. | 
| class  | PartitionWideEntryWithPredicateBackupOperation | 
| class  | PartitionWideEntryWithPredicateOperation | 
| class  | PutAllBackupOperation | 
| class  | PutAllOperationInserts the  MapEntriesfor a single partition to the localRecordStore. | 
| class  | PutBackupOperation | 
| class  | PutFromLoadAllBackupOperationRuns on backups. | 
| class  | PutFromLoadAllOperationPuts records to map which are loaded from map store by  IMap.loadAll(boolean) | 
| class  | PutIfAbsentOperation | 
| class  | PutOperation | 
| class  | PutTransientOperation | 
| class  | ReadonlyKeyBasedMapOperationAbstract  MapOperationthat serves as based for readonly operations. | 
| class  | RemoveBackupOperation | 
| class  | RemoveFromLoadAllOperationRemoves keys that are contained in the  RecordStorefrom the provided list, leaving only keys which are not contained in the record store. | 
| class  | RemoveIfSameOperation | 
| class  | RemoveOperation | 
| class  | ReplaceIfSameOperation | 
| class  | ReplaceOperation | 
| class  | SetOperation | 
| class  | SetTtlBackupOperation | 
| class  | SetTtlOperation | 
| class  | TriggerLoadIfNeededOperationTriggers key loading on member with  MapKeyLoader.Role.SENDERorMapKeyLoader.Role.SENDER_BACKUPkey
 loader role if keys have not yet been loaded. | 
| class  | TryPutOperation | 
| class  | TryRemoveOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueryOperation | 
| class  | QueryPartitionOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DestroyQueryCacheOperationThis operation removes all  QueryCacheresources on a node. | 
| class  | MadePublishableOperationSets  AccumulatorInfo.publishabletotrue. | 
| class  | PublisherCreateOperationAn idempotent create operation which creates publisher side functionality. | 
| class  | ReadAndResetAccumulatorOperationReads all available items from the accumulator of the partition and resets it. | 
| class  | SetReadCursorOperationSets read cursor of  Accumulatorin this partition to the supplied sequence number. | 
| 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 | Class and Description | 
|---|---|
| class  | PublishOperationITopic publication operation used when global ordering is enabled
 (all nodes listening to the same topic get their messages in the same order). | 
Copyright © 2020 Hazelcast, Inc.. All Rights Reserved.