| Package | Description | 
|---|---|
| com.hazelcast.aggregation.impl | |
| com.hazelcast.cache | 
     This package contains the public API extension for Hazelcast JCache,
     the Hazelcast implementation of the JSR-107 commonly referred to as JCache. | 
| com.hazelcast.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.cache.impl.event | 
     Event classes to define listenters for JCache other than EntryListener | 
| com.hazelcast.cache.impl.journal | |
| com.hazelcast.cache.impl.merge.entry | This package contains merge entry internal interfaces and functionality for Hazelcast cache. | 
| com.hazelcast.cache.impl.operation | Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.cache.impl.record | 
     Hazelcast JSR-107 aka JCache implementation
     Internal record store | 
| com.hazelcast.cardinality.impl | |
| com.hazelcast.cardinality.impl.hyperloglog | This package contains spec for the HyperLogLog data-structure. | 
| com.hazelcast.cardinality.impl.hyperloglog.impl | This package contains implementations of  HyperLogLog. | 
| com.hazelcast.cardinality.impl.operations | This package contains the operations on the  CardinalityEstimator. | 
| com.hazelcast.client.impl.operations | Contains client operations | 
| com.hazelcast.client.impl.protocol.task.cache | Client protocol tasks implementations for JCache | 
| com.hazelcast.client.impl.protocol.task.dynamicconfig | |
| com.hazelcast.client.impl.protocol.task.map | Client protocol tasks implementations for map | 
| com.hazelcast.cluster.impl | |
| com.hazelcast.collection.impl.collection | |
| 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.operations | This package contains the operations on the IAtomicLong. | 
| 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.config | Provides classes for configuring HazelcastInstance. | 
| com.hazelcast.crdt | This package contains CRDT (conflict-free replicated data type)
 implementations based on the Hazelcast infrastructure. | 
| com.hazelcast.crdt.pncounter | This package contains the PN (Positive-Negative) CRDT counter
 implementation. | 
| com.hazelcast.crdt.pncounter.operations | Contains the operations for the
  PNCountermember-side
 implementation. | 
| 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.instance | This package contains Hazelcast Instance functionality. | 
| com.hazelcast.internal.ascii.memcache | This package contains MemoryCache functionality for Hazelcast. | 
| com.hazelcast.internal.ascii.rest | This package contains Reset functionality for Hazelcast. | 
| com.hazelcast.internal.cluster | Contains the internals for cluster management like discovery, joining etc. | 
| 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.dynamicconfig | Classes related to Dynamic Configuration. | 
| com.hazelcast.internal.journal | This package contains supporting classes for data structure specific event journals. | 
| com.hazelcast.internal.management.dto | These contain the DTO object to exchange information with the management center. | 
| com.hazelcast.internal.management.operation | Contains operations that are called from Management Center. | 
| com.hazelcast.internal.management.request | Contains requests that made from Management Center. | 
| com.hazelcast.internal.nearcache.impl.invalidation | Invalidations for Near Cache. | 
| com.hazelcast.internal.partition | Contains the internals for partition assignment/management, migration, replication etc. | 
| com.hazelcast.internal.partition.operation | Contains the operations for partition package. | 
| com.hazelcast.internal.serialization.impl | |
| com.hazelcast.internal.usercodedeployment.impl | |
| com.hazelcast.internal.usercodedeployment.impl.operation | |
| com.hazelcast.map.eviction | This package contains eviction specific classes. | 
| com.hazelcast.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.iterator | |
| com.hazelcast.map.impl.journal | |
| com.hazelcast.map.impl.nearcache.invalidation | |
| 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.record | Contains record specific classes. | 
| com.hazelcast.map.impl.tx | Contains implementation classes for  TransactionalMap | 
| com.hazelcast.map.impl.wan | Contains wan replication event classes | 
| com.hazelcast.map.merge | Contains out-of-the-box merge policies for  IMap. | 
| com.hazelcast.mapreduce.aggregation.impl | This package contains a set of predefined aggregation implementations | 
| com.hazelcast.mapreduce.impl | This package contains the default implementation for the map reduce framework
 internals. | 
| com.hazelcast.mapreduce.impl.notification | This package contains all remote node notifications | 
| 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.nio | This package contains classes related to New IO | 
| com.hazelcast.nio.serialization | Contains interfaces/classes related to serialization;
 such as serializer interfaces, input/output streams. | 
| com.hazelcast.nio.serialization.impl | |
| com.hazelcast.projection.impl | |
| com.hazelcast.query | Contains interfaces/classes related to Hazelcast query and indexing support. | 
| com.hazelcast.query.impl | Contains the implementation classes of the query functionality. | 
| com.hazelcast.query.impl.predicates | |
| com.hazelcast.replicatedmap.impl.operation | This package contains replicated map operations which are executed on remote nodes | 
| com.hazelcast.replicatedmap.impl.record | This package contains the implementation of the backing data storage for the replicated map implementation | 
| com.hazelcast.ringbuffer.impl | Contains the  Ringbufferimplementation classes. | 
| com.hazelcast.ringbuffer.impl.operations | |
| com.hazelcast.scheduledexecutor | This package contains ScheduledExecutorService functionality for Hazelcast. | 
| com.hazelcast.scheduledexecutor.impl | |
| com.hazelcast.scheduledexecutor.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 | Contains the code for the  InternalEventServiceimplementation. | 
| com.hazelcast.spi.impl.eventservice.impl.operations | Contains the operations for the  EventServiceImpl. | 
| com.hazelcast.spi.impl.merge | This package contains split-brain related classes. | 
| com.hazelcast.spi.impl.operationservice.impl.operations | Contains the Operations being used by the  OperationServiceImpl. | 
| com.hazelcast.spi.impl.operationservice.impl.responses | Contains the different responses that can be send as a consequence of an Operation invocation. | 
| com.hazelcast.spi.impl.proxyservice.impl.operations | Contains the operations for the  ProxyServiceImpl. | 
| com.hazelcast.spi.merge | This package contains interfaces and classes of the split-brain merging SPI. | 
| 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.topic.impl.reliable | |
| 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 | |
| com.hazelcast.version | This package contains classes to support the versioning API. | 
| com.hazelcast.wan | This package contains the WAN replication API | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BigDecimalAverageAggregator<I> | 
| class  | BigDecimalSumAggregator<I> | 
| class  | BigIntegerAverageAggregator<I> | 
| class  | BigIntegerSumAggregator<I> | 
| class  | CountAggregator<I> | 
| class  | DistinctValuesAggregator<I,R> | 
| class  | DoubleAverageAggregator<I> | 
| class  | DoubleSumAggregator<I> | 
| class  | FixedSumAggregator<I> | 
| class  | FloatingPointSumAggregator<I> | 
| class  | IntegerAverageAggregator<I> | 
| class  | IntegerSumAggregator<I> | 
| class  | LongAverageAggregator<I> | 
| class  | LongSumAggregator<I> | 
| class  | MaxAggregator<I,R extends Comparable> | 
| class  | MaxByAggregator<I> | 
| class  | MinAggregator<I,R extends Comparable> | 
| class  | MinByAggregator<I> | 
| class  | NumberAverageAggregator<I> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HazelcastExpiryPolicyHazelcast provides overloads of the typical cache operations with a custom
  ExpiryPolicyparameter.This class provides a custom implementation of an ExpiryPolicyto
 react on all three types of policies:
 
 Create
 Access
 Update | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | CacheEventDataInternal event data wrapper used during publishing and dispatching events. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CacheClearResponseThis class is a simple object wrapper to be used by  CacheClearOperation. | 
| class  | CacheEntryIterationResultResponse data object returned by  CacheEntryIteratorOperation. | 
| class  | CacheEventDataImplImplementation of  CacheEventData. | 
| class  | CacheEventListenerAdaptor<K,V>This implementation of  CacheEventListeneruses the adapter pattern for wrapping all cache event listener
 types into a single listener. | 
| class  | CacheEventSetInternal Set wrapper of  CacheEventDataitems used during publishing and dispatching events. | 
| class  | CacheKeyIterationResultResponse data object returned by  CacheKeyIteratorOperation. | 
| class  | CachePartitionEventData | 
| class  | PreJoinCacheConfig<K,V>This subclass of  CacheConfigis used to communicate cache configurations in pre-join cache operations when cluster
 version is at least 3.9. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CachePartitionLostEventFilterUsed to filter partition lost listener events | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CacheEventJournalReadOperation<K,V,T>Reads from the cache event journal in batches. | 
| class  | CacheEventJournalReadResultSetImpl<K,V,T> | 
| class  | CacheEventJournalSubscribeOperationPerforms the initial subscription to the cache event journal. | 
| class  | DeserializingEventJournalCacheEvent<K,V> | 
| class  | InternalEventJournalCacheEventThe event journal item for map events. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DefaultCacheEntryViewDefault heap based implementation of  CacheEntryView. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCacheOperationBase Cache Operation. | 
| class  | AbstractMutatingCacheOperationBase class for all mutable cache operations. | 
| class  | AddCacheConfigOperation | 
| 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  | CacheClearOperationFactoryOperationFactoryimplementation for Clear Operations. | 
| 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  | CacheGetAllOperationGets all keys from the cache. | 
| class  | CacheGetAllOperationFactoryFactory implementation for  CacheGetAllOperation. | 
| 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  | CacheGetInvalidationMetaDataOperation | 
| static class  | CacheGetInvalidationMetaDataOperation.MetaDataResponse | 
| 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  | CacheLoadAllOperationFactoryFactory implementation for  CacheLoadAllOperation. | 
| 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  | CacheMergeOperationFactoryInserts the merging entries for all partitions of a member via locally invoked  CacheMergeOperation. | 
| class  | CacheNearCacheStateHolderHolder for Near Cache metadata. | 
| 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  | CacheRemoveAllOperationFactoryOperationFactoryimplementation for RemoveAll Operations. | 
| 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  | CacheSizeOperationFactoryFactory implementation of  CacheSizeOperation. | 
| class  | OnJoinCacheOperationOperation executed on joining members so they become aware of  CacheConfigs dynamically created viaCacheManager.createCache(String, Configuration). | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCacheRecord<V>Abstract implementation of  CacheRecordwith key, value and
 expiration time as internal state. | 
| class  | CacheDataRecordImplementation of  CacheRecordwhere value has an internal serialized format. | 
| class  | CacheObjectRecordImplementation of  CacheRecordwhich has an internal object format. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CardinalityEstimatorContainer | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | HyperLogLogHyperLogLog is a redundant and highly available distributed data-structure used for cardinality estimation
 purposes on unique items in significantly sized data cultures. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | HyperLogLogEncoder | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DenseHyperLogLogEncoder1. | 
| class  | HyperLogLogImpl | 
| class  | SparseHyperLogLogEncoder1. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCardinalityEstimatorOperation | 
| class  | AggregateBackupOperation | 
| class  | AggregateOperation | 
| class  | CardinalityEstimatorBackupAwareOperation | 
| class  | EstimateOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractClientOperation | 
| class  | ClientDisconnectionOperation | 
| class  | ClientReAuthOperation | 
| class  | GetConnectedClientsOperation | 
| class  | OnJoinClientOperation | 
| class  | OperationFactoryWrapper | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CacheAssignAndGetUuidsOperation | 
| class  | CacheAssignAndGetUuidsOperationFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| protected IdentifiedDataSerializable | AddQueueConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddLockConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddEventJournalConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddCacheConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddSemaphoreConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddFlakeIdGeneratorConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddSetConfigMessageTask. getConfig() | 
| protected abstract IdentifiedDataSerializable | AbstractAddConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddExecutorConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddScheduledExecutorConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddRingbufferConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddMultiMapConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddReplicatedMapConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddDurableExecutorConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddMapConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddReliableTopicConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddListConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddCardinalityEstimatorConfigMessageTask. getConfig() | 
| protected IdentifiedDataSerializable | AddTopicConfigMessageTask. getConfig() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapAssignAndGetUuidsOperation | 
| class  | MapAssignAndGetUuidsOperationFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | VectorClockVector clock consisting of distinct replica logical clocks. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CollectionContainer | 
| class  | CollectionEvent | 
| class  | CollectionEventFilter | 
| class  | CollectionItem | 
| class  | TxCollectionItem | 
| 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  | CollectionMergeBackupOperationCreates backups for merged collection items after split-brain healing with a  SplitBrainMergePolicy. | 
| class  | CollectionMergeOperationMerges a  SplitBrainMergeTypes.CollectionMergeTypesfor split-brain healing with aSplitBrainMergePolicy. | 
| class  | CollectionOperation | 
| class  | CollectionRemoveBackupOperation | 
| class  | CollectionRemoveOperation | 
| class  | CollectionReplicationOperation | 
| class  | CollectionSizeOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ListContainer | 
| 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 | Class and Description | 
|---|---|
| class  | QueueContainerThe  QueueContainercontains the actual queue and provides functionalities such as :
 
 queue functionalities
 transactional operation functionalities
 schedules queue destruction if it is configured to be destroyed once empty | 
| class  | QueueEventUsed for queue-wide events. | 
| class  | QueueEventFilterProvides the filtering functionality for Queue events. | 
| class  | QueueItemQueue Item. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CheckAndEvictOperationProvides eviction functionality for Operations of Queue. | 
| class  | ClearBackupOperationStore items' ID as set when ClearOperation run. | 
| class  | ClearOperationClears items stored by 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  | QueueReplicationOperationReplication operation for the Queue. | 
| class  | RemainingCapacityOperationReturns the remaining capacity of the queue based on config max-size | 
| class  | RemoveBackupOperationRemove backup of the Queue item. | 
| class  | RemoveOperationRemove operation for the Queue. | 
| class  | SizeOperationNotify size of the queue. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SetContainer | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SetReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CollectionTransactionLogRecordThis class contains Transaction log for the Collection. | 
| 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 | Class and Description | 
|---|---|
| class  | QueueTransactionLogRecordThis class contains Transaction log for the Queue. | 
| class  | TxQueueItemTransactional Queue Item. | 
| 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  | TxnPrepareBackupOperationProvides backup operation during transactional prepare operation. | 
| class  | TxnPrepareOperationPrepare 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. | 
| class  | TxnRollbackBackupOperationProvides backup operation during transactional rollback operation. | 
| class  | TxnRollbackOperationRollback operation for the transactional queue. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAtomicLongOperation | 
| class  | AddAndGetOperation | 
| class  | AtomicLongBackupAwareOperation | 
| class  | AtomicLongReplicationOperation | 
| class  | GetAndAddOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAlterOperation | 
| class  | AbstractAtomicReferenceOperation | 
| class  | AlterAndGetOperation | 
| class  | AlterOperation | 
| class  | ApplyOperation | 
| class  | AtomicReferenceBackupAwareOperation | 
| class  | AtomicReferenceReplicationOperation | 
| class  | CompareAndSetOperation | 
| class  | GetAndAlterOperation | 
| class  | GetAndSetOperation | 
| class  | IsNullOperation | 
| class  | SetAndGetOperation | 
| class  | SetBackupOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CountDownLatchContainer | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AwaitOperation | 
| class  | CountDownLatchBackupOperation | 
| class  | CountDownLatchReplicationOperation | 
| class  | CountDownOperation | 
| class  | GetCountOperation | 
| class  | SetCountOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LockStoreImpl | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractLockOperation | 
| class  | AwaitBackupOperation | 
| 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 | Class and Description | 
|---|---|
| class  | SemaphoreContainer | 
| 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 | 
| class  | SemaphoreReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractBasicConfig<T extends AbstractBasicConfig>Provides a basic configuration for a split-brain aware data structure. | 
| class  | AtomicLongConfigContains the configuration for an  AtomicLong. | 
| class  | AtomicReferenceConfigContains the configuration for an  AtomicReference. | 
| class  | CachePartitionLostListenerConfigConfiguration for CachePartitionLostListener | 
| class  | CachePartitionLostListenerConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | CacheSimpleConfigSimple configuration to hold parsed XML configuration. | 
| static class  | CacheSimpleConfig.ExpiryPolicyFactoryConfigRepresents configuration for "ExpiryPolicyFactory". | 
| static class  | CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfigRepresents duration configuration with duration amount and time unit
 for the "TimedExpiryPolicyFactoryConfig". | 
| static class  | CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfigRepresents configuration for time based "ExpiryPolicyFactory" with duration and time unit. | 
| class  | CacheSimpleConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | CacheSimpleEntryListenerConfigSimple configuration to hold parsed listener config. | 
| class  | CacheSimpleEntryListenerConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | CardinalityEstimatorConfigConfiguration options for the  CardinalityEstimator | 
| class  | CollectionConfig<T extends CollectionConfig>Provides configuration service for Collection. | 
| class  | CountDownLatchConfigContains the configuration for an  ICountDownLatch. | 
| class  | DurableExecutorConfigContains the configuration for an  DurableExecutorService. | 
| class  | EntryListenerConfigConfiguration for EntryListener | 
| static class  | EntryListenerConfig.MapListenerToEntryListenerAdapterWraps a MapListener into an EntryListener. | 
| class  | EntryListenerConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | EventJournalConfigConfiguration for an event journal. | 
| class  | ExecutorConfigContains the configuration for an  IExecutorService. | 
| class  | ExecutorConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | FlakeIdGeneratorConfigThe  FlakeIdGeneratorConfigcontains the configuration for the member
 regardingFlake ID Generator. | 
| class  | FlakeIdGeneratorConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | HotRestartConfigConfigures the Hot Restart Persistence per Hazelcast data structure. | 
| class  | ItemListenerConfigContains the configuration for an Item Listener. | 
| class  | ItemListenerConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | ListConfigContains the configuration for an  IList. | 
| class  | ListConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | ListenerConfigContains the configuration for an  EventListener. | 
| class  | ListenerConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | LockConfigContains the configuration for the  ILock. | 
| class  | MapAttributeConfigContains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor. | 
| class  | MapAttributeConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | MapConfigContains the configuration for an  IMap. | 
| class  | MapConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | MapIndexConfigContains the configuration for an index in a map. | 
| class  | MapIndexConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | MapPartitionLostListenerConfigConfiguration for MapPartitionLostListener | 
| class  | MapPartitionLostListenerConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | MapStoreConfigContains the configuration for a Map Store. | 
| class  | MapStoreConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | MergePolicyConfigConfiguration for  SplitBrainMergePolicy. | 
| class  | MultiMapConfigConfiguration for MultiMap. | 
| class  | MultiMapConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | NearCacheConfigContains the configuration for a Near Cache. | 
| class  | NearCacheConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | NearCachePreloaderConfigConfiguration for eviction. | 
| class  | PartitioningStrategyConfigContains the configuration for partitioning strategy. | 
| class  | PartitioningStrategyConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | PNCounterConfigConfiguration for a  PNCounter | 
| class  | PredicateConfigContains the configuration for an  Predicate. | 
| class  | QueryCacheConfigContains configuration for  QueryCache. | 
| class  | QueueConfigContains the configuration for an  IQueue. | 
| class  | QueueConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | QueueStoreConfigConfiguration for the  QueueStore. | 
| class  | QueueStoreConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | QuorumConfigConfiguration for cluster quorum, a means to protect consistency of data from network partitions. | 
| class  | QuorumListenerConfigConfiquration class for  QuorumListenerIMPORTANT: The term "quorum" simply refers to the count of members in the cluster required for an operation to succeed. | 
| class  | ReliableTopicConfigConfiguration for a reliable  ITopic. | 
| class  | ReplicatedMapConfigContains the configuration for an  ReplicatedMap | 
| class  | RingbufferConfigContains the configuration for the  Ringbuffer. | 
| class  | RingbufferStoreConfigConfiguration for the  RingbufferStore. | 
| class  | ScheduledExecutorConfigConfiguration options for the  IScheduledExecutorService. | 
| class  | SemaphoreConfigContains the configuration for an  ISemaphore. | 
| class  | SemaphoreConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | SetConfigContains the configuration for an  ISet. | 
| class  | SetConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | TopicConfigContains the configuration for a  ITopic. | 
| class  | TopicConfigReadOnlyDeprecated. 
 this class will be removed in 4.0; it is meant for internal usage only. | 
| class  | WanConsumerConfigConfig to be used by WanReplicationConsumer instances (EE only). | 
| class  | WanPublisherConfigConfiguration object for WAN publishers. | 
| class  | WanReplicationConfigConfiguration for WAN replication. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable>Base class for CRDT replication operations. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable>Base class for CRDT replication operations. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PNCounterImplPN (Positive-Negative) CRDT counter where each replica is identified by
 a String. | 
| class  | PNCounterReplicationOperationCRDT replication operation for a  PNCounter. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractPNCounterOperationBase class for  PNCounterquery and
 mutation operation implementations. | 
| class  | AddOperationAddition/subtraction operation for a
  PNCounter. | 
| class  | CRDTTimestampedLongResponse for CRDT PN counter operations which contains the PN counter
 value as well as the current replica vector clock. | 
| class  | GetOperationQuery operation to retrieve the current value of the
  PNCounter. | 
| 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  | RunnableAdapter<V> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CallableTaskOperation | 
| class  | CancellationOperation | 
| class  | MemberCallableTaskOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MemberImpl | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MemcacheEntry | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RestValue | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MemberInfo | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BindMessage | 
| class  | ClusterStateChange<T>Wrapper object indicating a change in the cluster state - it may be cluster state change or cluster version change. | 
| class  | ClusterStateTransactionLogRecordTransactionLogRecord implementation to be used in  ClusterStatetransactions. | 
| class  | ConfigCheckContains enough information about Hazelcast Config to do a validation check so that clusters with different configurations
 don't join. | 
| class  | JoinMessage | 
| class  | JoinRequest | 
| class  | MembersViewMembersView is a container object to carry member list and version together. | 
| class  | MembersViewMetadata | 
| class  | SplitBrainJoinMessageA  JoinMessageissued by the master node of a subcluster to the master of another subcluster
 while searching for other clusters for split brain recovery. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | JoinOperationMarker interface for join and post-join operations. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractJoinOperation | 
| class  | AuthenticationFailureOp | 
| class  | AuthorizationOp | 
| class  | BeforeJoinCheckFailureOp | 
| class  | CommitClusterStateOp | 
| class  | ConfigMismatchOpWhen a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated. | 
| class  | ExplicitSuspicionOpAn operation which is sent by a member that wants to be explicitly suspected by the target. | 
| class  | FetchMembersViewOpAn operation sent by the member that starts mastership claim process to fetch/gather member views of other members. | 
| class  | FinalizeJoinOpSent by the master to all members to finalize the join operation from a joining/returning node. | 
| class  | GroupMismatchOp | 
| class  | HeartbeatComplaintOp | 
| class  | HeartbeatOpA heartbeat sent from one cluster member to another. | 
| class  | JoinMastershipClaimOp | 
| class  | JoinRequestOp | 
| class  | LockClusterStateOp | 
| class  | MasterConfirmationOpDeprecated. 
 in 3.10 | 
| class  | MasterResponseOpOperation sent by any node to set the master address on the receiver | 
| class  | MemberAttributeChangedOp | 
| class  | MembersUpdateOp | 
| class  | MergeClustersOp | 
| class  | OnJoinOp | 
| class  | PromoteLiteMemberOpPromotes caller lite member to a normal member. | 
| class  | RollbackClusterStateOp | 
| class  | ShutdownNodeOp | 
| class  | SplitBrainMergeValidationOpValidate whether clusters may merge to recover from a split brain, based on configuration & cluster version. | 
| class  | TriggerExplicitSuspicionOpAn operation which is sent to trigger  ExplicitSuspicionOpon target member. | 
| class  | TriggerMemberListPublishOpRequests member list publish from master node | 
| class  | WhoisMasterOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractDynamicConfigOperation | 
| class  | AddDynamicConfigOperation | 
| class  | DynamicConfigPreJoinOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ClusterWideConfigurationService. broadcastConfig(IdentifiedDataSerializable config) | 
| void | ConfigurationService. broadcastConfig(IdentifiedDataSerializable config)Registers a dynamic configurations to all cluster members. | 
| ICompletableFuture<Object> | ClusterWideConfigurationService. broadcastConfigAsync(IdentifiedDataSerializable config) | 
| void | ClusterWideConfigurationService. registerConfigLocally(IdentifiedDataSerializable newConfig,
                     ConfigCheckMode configCheckMode)Register a dynamic configuration in a local member. | 
| Constructor and Description | 
|---|
| AddDynamicConfigOperation(IdentifiedDataSerializable config,
                         int memberListVersion) | 
| AddDynamicConfigOperationSupplier(ClusterService clusterService,
                                 IdentifiedDataSerializable config) | 
| DynamicConfigPreJoinOperation(IdentifiedDataSerializable[] configs,
                             ConfigCheckMode configCheckMode) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EventJournalInitialSubscriberStateThe response for the event journal subcription. | 
| class  | EventJournalReadOperation<T,J>Reads from the map event journal in batches. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapConfigDTOSerializable adapter for  MapConfig | 
| class  | PermissionConfigDTODTO object that provides serialization/deserialization support
 for  PermissionConfig | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractManagementOperation | 
| class  | AddWanConfigOperationOperation to add a new  WanReplicationConfigat runtime. | 
| class  | ChangeWanStateOperationEnables/Disable publishing events to target cluster in WAN Replication  WanReplicationServiceon a node. | 
| class  | ClearWanQueuesOperationClear WAN replication queues for the given wan replication schema and publisher | 
| 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. | 
| class  | UpdatePermissionConfigOperationPropagates  PermissionConfigchanges to members. | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | GetCacheEntryRequest.CacheBrowserEntryView | 
| static class  | GetCacheEntryRequest.GetCacheEntryViewEntryProcessor | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BatchNearCacheInvalidation | 
| class  | InvalidationRoot interface for Near Cache invalidation data. | 
| class  | SingleNearCacheInvalidationRepresents a single key invalidation. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MigrationInfo | 
| class  | NonFragmentedServiceNamespaceInternal  ServiceNamespaceimplementation used by partitioning system to identify
 non-fragmented service structures. | 
| class  | PartitionRuntimeState | 
| class  | ReplicaFragmentMigrationStateContains fragment namespaces along with their partition versions and migration data operations | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AssignPartitionsSent from non-master nodes to the master to initialize the partition assignment. | 
| class  | FetchPartitionStateOperationOperation sent by the master to the cluster members to fetch their partition state. | 
| class  | FinalizeMigrationOperationInvoked locally on the source or destination of the migration to finalize the migration. | 
| class  | HasOngoingMigration | 
| class  | MigrationCommitOperationSent by the master node to commit a migration on the migration destination. | 
| class  | MigrationOperationMigration operation used by Hazelcast version 3.9
 It runs on the migration destination and applies the received fragments. | 
| class  | MigrationRequestOperationMigration request operation used by Hazelcast version 3.9
 Sent from the master node to the partition owner. | 
| class  | PartitionBackupReplicaAntiEntropyOperation | 
| class  | PartitionReplicaSyncRequestThe request sent from a replica to the partition owner to synchronize the replica data. | 
| class  | PartitionReplicaSyncResponseThe replica synchronization response sent from the partition owner to a replica. | 
| class  | PartitionReplicaSyncRetryResponseThe response to a  PartitionReplicaSyncRequestthat the replica should retry. | 
| class  | PartitionStateOperationSent from the master to publish or sync the partition table state to all cluster members. | 
| class  | PromotionCommitOperationUsed for committing a promotion on destination. | 
| class  | SafeStateCheckOperationChecks whether a node is safe or not. | 
| class  | ShutdownRequestOperation | 
| class  | ShutdownResponseOperation | 
| Modifier and Type | Method and Description | 
|---|---|
| IdentifiedDataSerializable | ArrayDataSerializableFactory. create(int typeId) | 
| IdentifiedDataSerializable | ArrayDataSerializableFactory. create(int typeId,
      Version version) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClassDataCarries byte code of a class along with its inner classes. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClassDataFinderOperation | 
| class  | DeployClassesOperationOperation to distribute class definitions uploaded from client to cluster | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LFUEvictionPolicyLFU eviction policy for an  IMap | 
| class  | LRUEvictionPolicyLRU eviction policy for an  IMap | 
| class  | RandomEvictionPolicyRandom eviction policy for an  IMap | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EntryEventFilterEvent filter which matches events for a specified entry key. | 
| class  | EntryRemovingProcessor | 
| class  | EventListenerFilterEvent filter matching events of specified types. | 
| class  | LazyMapEntry<K,V>A  Map.Entryimplementation which serializes/de-serializes key and value objects on demand. | 
| class  | LockAwareLazyMapEntrySpecialization of the LazyMapEntry that is LockAware. | 
| class  | MapEntries | 
| class  | MapKeySet | 
| class  | MapPartitionLostEventFilter | 
| class  | MapValueCollection | 
| class  | SimpleEntryView<K,V>SimpleEntryView is an implementation of  EntryViewand also it is writable. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCursor<T>Base class for a cursor class holding a collection of items and the next position from which to resume fetching. | 
| class  | MapEntriesWithCursorContainer class for a collection of entries along with an offset from which new entries can be fetched. | 
| class  | MapKeysWithCursorContainer class for a collection of keys along with an offset from which new keys can be fetched. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DeserializingEventJournalMapEvent<K,V> | 
| class  | InternalEventJournalMapEventThe event journal item for map events. | 
| class  | MapEventJournalReadOperation<K,V,T>Reads from the map event journal in batches. | 
| class  | MapEventJournalReadResultSetImpl<K,V,T> | 
| class  | MapEventJournalSubscribeOperationPerforms the initial subscription to the map event journal. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | UuidFilterCompares supplied UUID with this filters' UUID to prevent unneeded delivery of an invalidation event to operation caller. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMapOperationFactory | 
| class  | AccumulatorConsumerOperationProcesses remaining items in  Accumulatorinstances on a partition. | 
| class  | AddIndexOperation | 
| class  | AddIndexOperationFactory | 
| class  | AddInterceptorOperation | 
| class  | AwaitMapFlushOperationIMap.flush()call waits the end of flush by using this operation. | 
| class  | BasePutOperation | 
| class  | BaseRemoveOperation | 
| class  | ClearExpiredOperationClears expired records. | 
| class  | ClearNearCacheOperationDeprecated.  | 
| class  | ClearOperationFactory | 
| class  | ContainsKeyOperation | 
| class  | ContainsValueOperation | 
| class  | ContainsValueOperationFactory | 
| 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  | EvictAllOperationFactoryOperation factory for evict all operations. | 
| class  | EvictBackupOperation | 
| class  | EvictBatchBackupOperationUsed to transfer expired keys from owner replica to backup replicas. | 
| class  | EvictOperation | 
| class  | GetEntryViewOperation | 
| class  | IsEmptyOperationFactory | 
| class  | IsKeyLoadFinishedOperationReturns if the key loading and dispatching has finished on this partition | 
| class  | IsPartitionLoadedOperation | 
| class  | IsPartitionLoadedOperationFactory | 
| class  | KeyBasedMapOperation | 
| class  | KeyLoadStatusOperationNotifies record store about completion of key loading. | 
| class  | KeyLoadStatusOperationFactoryFactory for  KeyLoadStatusOperation | 
| 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  | MapFlushOperationFactory | 
| class  | MapGetAllOperationFactory | 
| class  | MapGetInvalidationMetaDataOperation | 
| static class  | MapGetInvalidationMetaDataOperation.MetaDataResponse | 
| class  | MapIsEmptyOperation | 
| class  | MapLoadAllOperationFactoryOperation factory for load all operations. | 
| class  | MapNearCacheStateHolderHolder for Near Cache metadata. | 
| class  | MapOperation | 
| class  | MapPartitionDestroyOperationOperation to destroy the map data on the partition thread | 
| class  | MapReplicationOperationReplicates all IMap-states of this partition to a replica partition. | 
| class  | MapReplicationStateHolderHolder for raw IMap key-value pairs and their metadata. | 
| class  | MapSizeOperation | 
| class  | MergeOperationFactoryInserts the merging entries for all partitions of a member via locally invoked  MergeOperation. | 
| class  | MultipleEntryBackupOperation | 
| class  | MultipleEntryOperation | 
| class  | MultipleEntryOperationFactory | 
| class  | MultipleEntryWithPredicateBackupOperation | 
| class  | MultipleEntryWithPredicateOperation | 
| class  | NotifyMapFlushOperation | 
| class  | PartitionWideEntryBackupOperation | 
| class  | PartitionWideEntryOperationGOTCHA: This operation does NOT load missing keys from map-store for now. | 
| class  | PartitionWideEntryOperationFactory | 
| class  | PartitionWideEntryWithPredicateBackupOperation | 
| class  | PartitionWideEntryWithPredicateOperation | 
| class  | PartitionWideEntryWithPredicateOperationFactory | 
| class  | PostJoinMapOperation | 
| static class  | PostJoinMapOperation.InterceptorInfo | 
| class  | PutAllBackupOperation | 
| class  | PutAllOperationInserts the  MapEntriesfor a single partition to the localRecordStore. | 
| class  | PutAllPartitionAwareOperationFactoryInserts the  MapEntriesfor all partitions of a member via locally invokedPutAllOperation. | 
| class  | PutFromLoadAllBackupOperationRuns on backups. | 
| class  | PutFromLoadAllOperationPuts records to map which are loaded from map store by  IMap.loadAll(boolean) | 
| class  | PutIfAbsentOperation | 
| class  | PutTransientOperation | 
| class  | ReadonlyKeyBasedMapOperationAbstract  MapOperationthat serves as based for readonly operations. | 
| 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  | RemoveInterceptorOperation | 
| class  | ReplaceIfSameOperation | 
| class  | ReplaceOperation | 
| class  | SetOperation | 
| class  | SizeOperationFactory | 
| 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 | 
| class  | WriteBehindStateHolderHolder for write-behind-specific state. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | Result<T extends Result>Result of a Query. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AggregationResultContains the result of the evaluation of an aggregation on a specific Partition or Node. | 
| class  | QueryObject representing a Query together with all possible co-variants: like a predicate, iterationType, etc. | 
| class  | QueryEventFilterEvent filter which mathes map events on a specified entry key and matching a predefined  Predicate. | 
| class  | QueryOperation | 
| class  | QueryPartitionOperation | 
| class  | QueryResultRepresents a result of the query execution in the form of an iterable
 collection of  rows. | 
| class  | QueryResultRowThis interfaces provides methods related to entry of the query result. | 
| class  | ResultSegmentRepresents a partial query result on a segment of the map. | 
| class  | TargetTarget for a query. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DestroyQueryCacheOperationThis operation removes all  QueryCacheresources on a node. | 
| class  | MadePublishableOperationSets  AccumulatorInfo.publishabletotrue. | 
| class  | MadePublishableOperationFactoryOperation factory for  MadePublishableOperation. | 
| 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  | RecordInfoRecord info. | 
| class  | RecordReplicationInfo | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapTransactionLogRecordRepresents an operation on the map in the transaction log. | 
| class  | TxnDeleteOperationTransactional delete operation | 
| 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. | 
| class  | VersionedValueWrapper for  Datavalue objects with version information. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapReplicationRemove | 
| class  | MapReplicationUpdateWAN replication object for map update operations. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HigherHitsMapMergePolicyMerges map entries from source to destination map if the source entry
 has more hits than the destination one. | 
| class  | IgnoreMergingEntryMapMergePolicyIgnores the merging entry while collecting merge-needed entries on merging side. | 
| class  | LatestUpdateMapMergePolicyMerges map entries from source to destination map if the source entry
 was updated more recently than the destination entry. | 
| class  | PassThroughMergePolicyMerges map entries from source to destination directly unless the merging entry is  null. | 
| class  | PutIfAbsentMapMergePolicyMerges map entries from source to destination if they don't exist in the destination map. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AcceptAllSupplier<KeyIn,ValueIn,ValueOut>A standard implementation of the  Supplierinterface which accepts all input values and may apply a givenPropertyExtractoron those. | 
| class  | AvgTuple<F,S>Internal tuple type for average calculations, used to transmit data between
 Combiner and Reducer implementations. | 
| class  | KeyPredicateSupplier<KeyIn,ValueIn,ValueOut>The default supplier for  KeyPredicates, used
 to filter and optionally transform data (using the givenSupplier). | 
| class  | PredicateSupplier<KeyIn,ValueIn,ValueOut> | 
| class  | SetAdapter<E>A simple adapter class to serialize values of a  Setusing
 Hazelcast serialization support. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CombinerResultList<E> | 
| class  | HashMapAdapter<K,V>Simple HashMap adapter class to implement DataSerializable serialization semantics
 to not loose hands on serialization while sending intermediate results. | 
| class  | ListKeyValueSource<V>This  KeyValueSourceimplementation is used inKeyValueSource.fromList(com.hazelcast.core.IList)to generate a default
 implementation based on a HazelcastIList. | 
| class  | MapKeyValueSource<K,V>This  KeyValueSourceimplementation is used inKeyValueSource.fromMap(com.hazelcast.core.IMap)to generate a default
 implementation based on a HazelcastIMap. | 
| class  | MultiMapKeyValueSource<K,V>This  KeyValueSourceimplementation is used inKeyValueSource.fromMultiMap(com.hazelcast.core.MultiMap)to generate a default
 implementation based on a HazelcastMultiMap. | 
| class  | SetKeyValueSource<V>This  KeyValueSourceimplementation is used inKeyValueSource.fromSet(com.hazelcast.core.ISet)to generate a default
 implementation based on a HazelcastISet. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | IntermediateChunkNotification<KeyOut,Value>Notification that is fired every time the chunk limit is reached and is send to the reducers | 
| class  | LastChunkNotification<KeyOut,Value>This notification is used to notify the reducer that this chunk is the last chunk of the
 defined partitionId. | 
| class  | MapReduceNotificationBase class for all map reduce framework notifications | 
| class  | MemberAwareMapReduceNotificationBase class for all notifications based on a member | 
| class  | ReducingFinishedNotificationThis notification class is used to signal the  JobSupervisorowner node that a reducer has finished the reducing step for the defined partitionId. | 
| 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  | GetResultOperationFactoryThis class is used to create  GetResultOperationinstances. | 
| class  | KeysAssignmentOperationThis operation is used to request assignment for keys on the job owners node. | 
| class  | KeysAssignmentResultThis class is used to store assignment results in  KeysAssignmentOperationexecutions. | 
| 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  | RequestPartitionResultThis class is used to store the requested result of all kinds of processing operations. By default it holds a basic result state and maybe the partitionId it was operated otherwise it's value is defined as -1 | 
| 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 | Class and Description | 
|---|---|
| class  | MultiMapEventFilter | 
| class  | MultiMapMergeContainerContainer for the merge operation of a  MultiMap. | 
| class  | MultiMapRecord | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractBackupAwareMultiMapOperation | 
| class  | AbstractKeyBasedMultiMapOperation | 
| class  | AbstractMultiMapOperation | 
| class  | ContainsEntryOperation | 
| class  | CountOperation | 
| class  | DeleteBackupOperation | 
| class  | DeleteOperation | 
| class  | EntrySetOperation | 
| class  | EntrySetResponse | 
| class  | GetAllOperation | 
| class  | KeySetOperation | 
| class  | MultiMapOperationFactory | 
| class  | MultiMapReplicationOperation | 
| class  | MultiMapResponse | 
| class  | PutBackupOperation | 
| class  | PutOperation | 
| class  | RemoveAllBackupOperation | 
| class  | RemoveAllOperation | 
| class  | ValuesOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MultiMapTransactionLogRecord | 
| class  | TxnGenerateRecordIdOperation | 
| class  | TxnLockAndGetOperation | 
| class  | TxnPutBackupOperation | 
| class  | TxnPutOperation | 
| class  | TxnRemoveAllBackupOperation | 
| class  | TxnRemoveAllOperation | 
| class  | TxnRemoveBackupOperation | 
| class  | TxnRemoveOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddressRepresents an address of a member in the cluster. | 
| Modifier and Type | Method and Description | 
|---|---|
| IdentifiedDataSerializable | DataSerializableFactory. create(int typeId)Creates an IdentifiedDataSerializable instance using given type ID | 
| Modifier and Type | Method and Description | 
|---|---|
| IdentifiedDataSerializable | VersionedDataSerializableFactory. create(int typeId,
      Version version)Creates an IdentifiedDataSerializable instance using given type ID and object version | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | IdentityProjection<I> | 
| class  | MultiAttributeProjection<I>Projection that extracts the values of the given attributes and returns them in an Object[] array. | 
| class  | SingleAttributeProjection<I,O>Projection that extracts the values of the given attribute and returns it. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PagingPredicate<K,V>This class is a special Predicate which helps to get a page-by-page result of a query. | 
| class  | PartitionPredicate<K,V>A  Predicatethat restricts the execution of a Predicate to a single Partition. | 
| class  | SqlPredicateThis class contains methods related to conversion of sql query to predicate. | 
| class  | TruePredicate<K,V>A  Predicatewhich always returns true. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FalsePredicate<K,V>A  Predicatewhich always returns false. | 
| static class  | IndexImpl.NullObject | 
| class  | IndexInfo | 
| class  | MapIndexInfo | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractIndexAwarePredicate<K,V> | 
| class  | AbstractPredicate<K,V>Provides base features for predicates, such as extraction and conversion of the attribute's value. | 
| class  | AndPredicateAnd Predicate | 
| class  | BetweenPredicateBetween Predicate | 
| class  | EqualPredicateEqual Predicate | 
| class  | GreaterLessPredicateGreater Less Predicate | 
| class  | ILikePredicateIlike Predicate | 
| class  | InPredicateIn Predicate | 
| class  | InstanceOfPredicatePredicate version of `instaceof` operator from Java. | 
| class  | LikePredicateLike Predicate | 
| class  | NotEqualPredicateNot Equal Predicate | 
| class  | NotPredicateNot Predicate | 
| class  | OrPredicateOr Predicate | 
| class  | RegexPredicateRegex Predicate | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractNamedSerializableOperation | 
| class  | AbstractReplicatedMapOperation | 
| class  | AbstractSerializableOperation | 
| class  | CheckReplicaVersionOperationChecks whether replica version is in sync with the primary. | 
| class  | EvictionOperationEvicts set of entries from the record store. | 
| class  | PutAllOperationFactoryFactory class for  PutAllOperation. | 
| 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  | SyncReplicatedMapDataOperation<K,V>Carries set of replicated map records for a partition from one node to another | 
| class  | VersionResponsePairContains response and partition version for update operations on replicated map. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RecordMigrationInfo | 
| class  | ReplicatedMapEntryView<K,V> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReadResultSetImpl<O,E>A list for the  ReadManyOperation. | 
| class  | RingbufferContainer<T,E>The RingbufferContainer is responsible for the functionalities supporting
 the underlying ringbuffer structure containing the data. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractRingBufferOperationCommon logic for all ring buffer operations :
 
 getting the ring buffer container or creating a new one if necessary
 serialization/deserialization of ring buffer name
 defines the factory ID for the  IdentifiedDataSerializable | 
| class  | AddAllBackupOperationBackup operation for ring buffer  AddAllOperation. | 
| class  | AddAllOperationAdds a batch of items to the ring buffer. | 
| class  | AddBackupOperationBackup operation for ring buffer  AddOperation. | 
| class  | GenericOperationRing buffer operations which don't need to send any parameters and which can be determined by only sending the operation
 type which is a byte of information. | 
| class  | MergeBackupOperationContains the entire ringbuffer as a result of split-brain healing with a
  SplitBrainMergePolicy. | 
| class  | MergeOperationContains an entire ringbuffer for split-brain healing with a
  SplitBrainMergePolicy. | 
| class  | ReadManyOperation<O> | 
| class  | ReadOneOperation | 
| class  | ReplicationOperation | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ScheduledTaskStatisticsStatistics and timing info for a  IScheduledFutureaccessible throughIScheduledFuture.getStats() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ScheduledTaskHandlerResource handler pointing to a  IScheduledFuture. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NamedTaskDecorator<V> | 
| class  | ScheduledRunnableAdapter<V> | 
| class  | ScheduledTaskDescriptorMetadata holder for scheduled tasks. | 
| class  | ScheduledTaskHandlerImpl | 
| class  | ScheduledTaskResult | 
| class  | ScheduledTaskStatisticsImpl | 
| class  | TaskDefinition<V> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractBackupAwareSchedulerOperation | 
| class  | AbstractGetAllScheduledOperation | 
| class  | AbstractSchedulerOperation | 
| class  | CancelTaskBackupOperation | 
| class  | CancelTaskOperation | 
| class  | DisposeBackupTaskOperation | 
| class  | DisposeTaskOperation | 
| class  | GetAllScheduledOnMemberOperation | 
| class  | GetAllScheduledOnPartitionOperation | 
| class  | GetAllScheduledOnPartitionOperationFactory | 
| class  | GetDelayOperation | 
| class  | GetResultOperation<V> | 
| class  | GetStatisticsOperation | 
| class  | IsCanceledOperation | 
| class  | IsDoneOperation | 
| class  | ResultReadyNotifyOperation<V> | 
| class  | ScheduleTaskBackupOperation | 
| class  | ScheduleTaskOperation | 
| class  | SyncBackupStateOperation | 
| class  | SyncStateOperation | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | OperationFactoryA Factory for creating  Operationinstances. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractLocalOperationAbstract class for local operations, which should not be serializable. | 
| class  | DistributedObjectNamespaceDefault  ObjectNamespaceimplementation forDistributedObject. | 
| class  | OperationControlContent of an Operation Control packet:
 
 a list of operations the remote member started on this member which are still running;
 a list of operations this member wants to cancel on the remote member.
 
 Operations are identified by their call ID. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractNamedOperation | 
| class  | BinaryOperationFactory | 
| class  | SerializableList | 
| class  | UnmodifiableLazyList<E> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EventEnvelopeAn Envelope around an event object. | 
| class  | TrueEventFilterAn event filter which does not filter any event and always evaluates  trueresults. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DeregistrationOperation | 
| class  | OnJoinRegistrationOperation | 
| class  | RegistrationOperation | 
| class  | SendEventOperationAn operation for sending a event to a remote subscriber (not on this node). | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | Backup | 
| class  | PartitionAwareOperationFactoryCreates partition specific operations. | 
| class  | PartitionIteratingOperationExecutes Operations on one or more partitions. | 
| static class  | PartitionIteratingOperation.PartitionResponse | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BackupAckResponseThe {Response} for a  BackupOperation. | 
| class  | CallTimeoutResponseAn response that indicates that the execution of a single call ran into a timeout. | 
| class  | ErrorResponse | 
| class  | NormalResponseA NormalResponse is send when an Operation needs to return a value. | 
| class  | Response | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DistributedObjectDestroyOperation | 
| class  | InitializeDistributedObjectOperation | 
| class  | PostJoinProxyOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DiscardMergePolicy<V,T extends MergingValue<V>>Merges only entries from the destination data structure and discards all entries from the source data structure. | 
| class  | ExpirationTimeMergePolicy<V,T extends MergingExpirationTime<V>>Merges data structure entries from source to destination data structure if the source entry
 will expire later than the destination entry. | 
| class  | HigherHitsMergePolicy<V,T extends MergingHits<V>>Merges data structure entries from source to destination data structure if the source entry
 has more hits than the destination one. | 
| class  | HyperLogLogMergePolicyOnly available for HyperLogLog backed  CardinalityEstimator. | 
| class  | LatestAccessMergePolicy<V,T extends MergingLastAccessTime<V>>Merges data structure entries from source to destination data structure if the source entry
 has been accessed more recently than the destination entry. | 
| class  | LatestUpdateMergePolicy<V,T extends MergingLastUpdateTime<V>>Merges data structure entries from source to destination data structure if the source entry
 was updated more frequently than the destination entry. | 
| class  | PutIfAbsentMergePolicy<V,T extends MergingValue<V>>Merges data structure entries from source to destination if they don't exist in the destination data structure. | 
| 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). | 
| class  | TopicEvent | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReliableTopicMessageThe Object that is going to be stored in the Ringbuffer. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | TargetAwareTransactionLogRecordRepresents a change made in a transaction on a specific target Address. | 
| interface  | TransactionLogRecordRepresents a change made in a transaction e.g. | 
| 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 | Class and Description | 
|---|---|
| class  | XATransactionDTO | 
| 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 | Class and Description | 
|---|---|
| class  | MemberVersionDetermines the Hazelcast codebase version in terms of major.minor.patch version. | 
| class  | VersionA generic version to be used with  VersionAwareclasses. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | WanReplicationEventEvent class used to transmit the actual event object | 
Copyright © 2018 Hazelcast, Inc.. All Rights Reserved.