| Package | Description | 
|---|---|
| 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.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.client.impl.client | This contains the Requests and other DTO's exchanged between client/server | 
| com.hazelcast.client.impl.operations | Contains client operations | 
| com.hazelcast.cluster | This package contains the cluster functionality. | 
| com.hazelcast.cluster.client | This package contains the client cluster functionality. | 
| com.hazelcast.cluster.impl | This package contains the implementation of the cluster functionality. | 
| com.hazelcast.cluster.impl.operations | This package contains operations for the com.hazelcast.cluster.impl package. | 
| 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.console | This package contains classes related to ConsoleApp | 
| com.hazelcast.core | Provides core API interfaces/classes. | 
| com.hazelcast.executor.impl | This package contains IExecutorService functionality for Hazelcast. The IExecutorService extends the ExecutorServiceand provides all kinds
 of additional methods related to distributed systems. | 
| com.hazelcast.executor.impl.operations | This package contains operations for the IExecutorService. | 
| com.hazelcast.hibernate | Contains interfaces/classes related to Hibernate. | 
| com.hazelcast.hibernate.distributed | Provides distributed class for Hibernate. | 
| com.hazelcast.hibernate.local | Provides local classes for Hibernate. | 
| com.hazelcast.hibernate.serialization | This class contains the Hibernate4 serializer hooks so what we don't
 loose handling on serialization while working on hibernate | 
| 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.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.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.event | |
| com.hazelcast.map.impl.operation | Package for map operations. | 
| com.hazelcast.map.impl.query | |
| com.hazelcast.map.impl.querycache.event | This package contains classes for query cache events. | 
| 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 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.mapreduce.impl.task | This package contains the base implementation for a standard map reduce job. | 
| 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.partition | Contains the partition logic for Hazelcast. | 
| com.hazelcast.partition.client | Contains client functionality for partition related information. | 
| com.hazelcast.partition.impl | Contains the actual implementation of the  InternalPartitionService. | 
| 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.replicatedmap.merge | Contains merge policies for  ReplicatedMap | 
| com.hazelcast.ringbuffer.impl | Contains the  Ringbufferimplementation classes. | 
| com.hazelcast.ringbuffer.impl.operations | |
| com.hazelcast.spi | Provides interfaces/classes for Hazelcast SPI. | 
| 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.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 | Contains the implementation of the  InternalProxyService. | 
| com.hazelcast.spi.impl.proxyservice.impl.operations | Contains the operations for the  ProxyServiceImpl. | 
| com.hazelcast.topic.impl | This package contains ITopic functionality for Hazelcast. With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. | 
| com.hazelcast.topic.impl.reliable | |
| com.hazelcast.transaction | Provides interfaces/classes for Hazelcast transaction support. | 
| 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.wan | This package contains the WAN replication API | 
| com.hazelcast.web | Provides Hazelcast-based session replication. | 
| com.hazelcast.web.entryprocessor | Provides Entry Processors used in hazelcast-wm | 
| 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  | CacheEventDataImplImplementation of  CacheEventData. | 
| class  | CacheEventSetInternal Set wrapper of  CacheEventDataitems used during publishing and dispatching events. | 
| class  | CacheKeyIteratorResultResponse data object returned by  CacheKeyIteratorOperation. | 
| class  | CachePartitionEventData | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CachePartitionLostEventFilterUsed to filter partition lost listener events | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DefaultCacheEntryViewDefault heap based implementation of  CacheEntryView. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMutatingCacheOperationBase class for all mutable cache operations. | 
| class  | CacheBackupEntryProcessorOperationOperation of the Cache Backup Entry Processor. | 
| class  | CacheClearBackupOperationBackup operation of  CacheClearOperation. | 
| class  | CacheClearOperationCache Clear will clear all internal cache data without sending any event | 
| class  | CacheClearOperationFactoryOperationFactoryimplementation for Clear Operations. | 
| class  | CacheContainsKeyOperationCache contains key operation, determines if the cache contains an entry for the specified key. | 
| class  | CacheCreateConfigOperationUsed to create cluster wide cache configuration. | 
| class  | CacheDestroyOperationDestroys the cache on the cluster or on a single node by calling
  CacheService#deleteCache(String, boolean, String, boolean). | 
| 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  | CacheGetConfigOperationCache GetConfig Operation. | 
| class  | CacheGetOperationCache Get Operation. | 
| class  | CacheKeyIteratorOperationProvides iterator functionality for ICache. | 
| class  | CacheListenerRegistrationOperationListener can be registered and unregistered by  CacheService. | 
| class  | CacheLoadAllOperationLoads all entries of the keys to partition record store  ICacheRecordStore. | 
| class  | CacheLoadAllOperationFactoryFactory implementation for  CacheLoadAllOperation. | 
| class  | CacheManagementConfigOperationCache ManagementConfig Operation provides enabling/disabling the functionality of  management and
 statistics mxbeans of the cache. | 
| class  | CacheMergeOperation | 
| class  | CachePutAllBackupOperationCache PutAllBackup Operation is the backup operation used by load all operation. | 
| class  | CachePutAllOperation | 
| class  | CachePutBackupOperationBackup operation for the operation of adding cache entries into record stores. | 
| class  | CachePutIfAbsentOperationOperation implementation for calling
  ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int). | 
| class  | CachePutOperationOperation implementation for
  ICacheRecordStore.put(Data, Object, ExpiryPolicy, String, int)andICacheRecordStore.getAndPut(Data, Object, ExpiryPolicy, String, int). | 
| class  | CacheRemoveAllBackupOperationBackup operation of  CacheRemoveAllOperation. | 
| class  | CacheRemoveAllOperationTODO add a proper JavaDoc | 
| class  | 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  | PostJoinCacheOperation | 
| 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  | ClientResponse | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientDisconnectionOperation | 
| class  | ClientReAuthOperation | 
| class  | GetConnectedClientsOperation | 
| class  | OperationFactoryWrapper | 
| class  | PostJoinClientOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MemberInfo | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientInitialMembershipEvent | 
| class  | ClientMembershipEvent | 
| class  | MemberAttributeChange | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BindMessage | 
| 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 | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AuthenticationFailureOperation | 
| class  | AuthorizationOperation | 
| class  | BeforeJoinCheckFailureOperation | 
| class  | ChangeClusterStateOperation | 
| class  | ConfigMismatchOperationWhen a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated. | 
| class  | FinalizeJoinOperation | 
| class  | GroupMismatchOperation | 
| class  | HeartbeatOperation | 
| class  | JoinCheckOperation | 
| class  | JoinRequestOperation | 
| class  | LockClusterStateOperation | 
| class  | MasterClaimOperation | 
| class  | MasterConfirmationOperation | 
| class  | MasterDiscoveryOperation | 
| class  | MemberAttributeChangedOperation | 
| class  | MemberInfoUpdateOperation | 
| class  | MemberRemoveOperation | 
| class  | MergeClustersOperation | 
| class  | PostJoinOperation | 
| class  | RollbackClusterStateOperation | 
| class  | SetMasterOperation | 
| class  | ShutdownNodeOperation | 
| class  | TriggerMemberListPublishOperationRequests member list publish from master node | 
| 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  | 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  | QueueContainerThis class contains methods be notable for the Queue. | 
| 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  | 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  | CollectionTransactionLogRecord | 
| Modifier and Type | Class and Description | 
|---|---|
| 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  | QueueTransactionRollbackOperationTransaction Rollback Operation for the Queue. | 
| class  | TxnOfferBackupOperationProvides backup operation during transactional offer operation. | 
| class  | TxnOfferOperationOffer operation for the Transactional Queue. | 
| class  | TxnPeekOperationPeek operation for the transactional queue. | 
| class  | TxnPollBackupOperationProvides backup operation during transactional poll operation. | 
| class  | TxnPollOperationPoll operation for the transactional queue. | 
| class  | TxnPrepareBackupOperationProvides backup operation during transactional prepare operation. | 
| class  | TxnPrepareOperationPrepare operation for the transactional queue. | 
| class  | TxnReserveOfferBackupOperationReserve offer backup operation for the transactional queue. | 
| class  | TxnReserveOfferOperationReserve offer operation for the transactional queue. | 
| class  | TxnReservePollBackupOperationReserve poll backup operation for the transactional queue. | 
| class  | TxnReservePollOperationReserve poll operation for the transactional queue. | 
| class  | TxnRollbackBackupOperationProvides backup operation during transactional rollback operation. | 
| class  | TxnRollbackOperationRollback operation for the transactional queue. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AddAndGetOperation | 
| class  | AtomicLongBackupAwareOperation | 
| class  | AtomicLongBaseOperation | 
| class  | AtomicLongReplicationOperation | 
| class  | GetAndAddOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAlterOperation | 
| class  | AlterAndGetOperation | 
| class  | AlterOperation | 
| class  | ApplyOperation | 
| class  | AtomicReferenceBackupAwareOperation | 
| class  | AtomicReferenceBaseOperation | 
| 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  | InternalLockNamespace | 
| class  | LockStoreImpl | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AwaitBackupOperation | 
| class  | BaseLockOperation | 
| 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  | DeadMemberBackupOperation | 
| class  | InitBackupOperation | 
| class  | InitOperation | 
| class  | ReduceBackupOperation | 
| class  | ReduceOperation | 
| class  | ReleaseBackupOperation | 
| class  | ReleaseOperation | 
| class  | SemaphoreBackupAwareOperation | 
| class  | SemaphoreBackupOperation | 
| class  | SemaphoreDeadMemberOperation | 
| class  | SemaphoreOperation | 
| class  | SemaphoreReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CacheConfig<K,V>Contains all the configuration for the  ICache. | 
| class  | CacheConfigReadOnly<K,V>Readonly version of  CacheConfig | 
| class  | CacheEvictionConfigDeprecated. 
 Use  EvictionConfiginstead of this | 
| class  | CacheEvictionConfigReadOnlyDeprecated. 
 Use  EvictionConfigReadOnlyinstead of this | 
| class  | EvictionConfigConfiguration for eviction. | 
| class  | EvictionConfigReadOnlyRead only version of  EvictionConfig. | 
| class  | MaxSizeConfigConfiguration for map's capacity. | 
| class  | MaxSizeConfigReadOnlyContains the configuration for a size of Map. | 
| class  | NearCacheConfigContains configuration for an NearCache. | 
| class  | NearCacheConfigReadOnlyContains configuration for an NearCache(Read-Only). | 
| class  | WanReplicationRefConfiguration for Wan target replication reference | 
| class  | WanReplicationRefReadOnlyConfiguration for Wan target replication reference(read only) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EchoEchoes to screen | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | MemberCluster member interface. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MemberAttributeEvent | 
| class  | MigrationEventAn event fired when a partition migration starts, completes or fails. | 
| class  | PartitionAwareKey<K,P>A  PartitionAwarekey. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RunnableAdapter<V> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CallableTaskOperation | 
| class  | CancellationOperation | 
| class  | MemberCallableTaskOperation | 
| class  | ShutdownOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | VersionAwareMapMergePolicyA merge policy implementation to handle split brain remerges based on the timestamps stored in
  the values. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractRegionCacheEntryProcessorAn abstract implementation of  EntryProcessorwhich acts on a hibernate region cacheIMap | 
| class  | LockEntryProcessorA concrete implementation of  EntryProcessorwhich soft-locks
 a region cached entry | 
| class  | UnlockEntryProcessorA concrete implementation of  EntryProcessorwhich unlocks
 a soft-locked region cached entry | 
| class  | UpdateEntryProcessorA concrete implementation of  EntryProcessorwhich attempts
 to update a region cache entry | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | InvalidationAn invalidation messages | 
| class  | TimestampHazelcast compatible implementation of a timestamp for internal eviction | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ExpirableA container class which represents an entry in a region cache which can be marked for expiration | 
| class  | ExpiryMarkerAn entry which is marked for expiration. | 
| class  | ValueA value within a region cache | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMember | 
| 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  | MapConfigDTOSerializable adapter for  MapConfig | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ChangeWanStateOperationEnables/Disable publishing events to target cluster in WAN Replication  WanReplicationServiceon a node. | 
| class  | GetMapConfigOperationOperation to fetch Map configuration. | 
| class  | ScriptExecutorOperationOperation to execute script on the node. | 
| class  | ThreadDumpOperationOperation for generating thread dumps. | 
| class  | UpdateManagementCenterUrlOperationOperation to update Management Center URL configured on the node. | 
| class  | UpdateMapConfigOperationOperation to update map configuration from Management Center. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EntryEventFilter | 
| class  | EventListenerFilterPrevents sending of not requested events to a  MapListenerby filtering events according the implementedMapListenersub-interfaces. | 
| class  | MapEntriesMapEntries is a collection of  Map.Entryinstances. | 
| class  | MapKeySet | 
| class  | MapPartitionLostEventFilter | 
| class  | MapValueCollection | 
| class  | SimpleEntryView<K,V>SimpleEntryView is an implementation of  EntryViewand also it is writable. | 
| class  | SyntheticEventFilterWrapper class for a filter which does not want to receive synthetic events. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | EventDataGeneral contract for map event data. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EntryEventDataAn entry's event data. | 
| class  | MapEventDataMap wide event's data. | 
| class  | MapPartitionEventDataContains the data related to a map partition event | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueryEventFilter | 
| class  | QueryOperation | 
| class  | QueryPartitionOperation | 
| class  | QueryResultContains the result of a query evaluation. | 
| class  | QueryResultRowThis interfaces provides methods related to entry of the query result. | 
| class  | QueryResultSetDeprecated. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | QueryCacheEventDataEvent data contract which is sent to subscriber side. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DefaultQueryCacheEventDataDefault implementation of  QueryCacheEventDatawhich is sent to subscriber. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | RecordStatisticsRepresents statistics of a  Record. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EmptyRecordStatisticsEmpty  RecordStatisticsimplementation which returns zero for all stats. | 
| class  | RecordInfoRecord info. | 
| class  | RecordReplicationInfo | 
| class  | RecordStatisticsImplStatistics of a  Record | 
| 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  | MapReplicationUpdate | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | MapMergePolicyA policy for merging maps after a splitbrain was detected and the different network partitions need
 to be merged. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HigherHitsMapMergePolicyHigherHitsMapMergePolicy causes the merging entry to be merged from source to destination map
 if source entry has more hits than the destination one. | 
| class  | LatestUpdateMapMergePolicyLatestUpdateMapMergePolicy causes the merging entry to be merged from source to destination map
 if source entry has updated more recently than the destination entry. | 
| class  | PassThroughMergePolicyPassThroughMergePolicy causes the merging entry to be merged from source to destination map
 unless merging entry is null. | 
| class  | PutIfAbsentMapMergePolicyPutIfAbsentMapMergePolicy causes the merging entry to be merged from source to destination map
 if it does not 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  | GetResultOperationThis operation is used to retrieve results from a remote node | 
| class  | GetResultOperationFactoryThis class is used to create  GetResultOperationinstances.In difference to other implementations of OperationFactorythis class
 is never ever serialized and the DataSerializable methodsGetResultOperationFactory.readData(com.hazelcast.nio.ObjectDataInput)andGetResultOperationFactory.writeData(com.hazelcast.nio.ObjectDataOutput)throwUnsupportedOperationExceptions. | 
| 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  | JobPartitionStateImplThis class holds information about the current processing state and the owner of a partition | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MultiMapEventFilter | 
| class  | MultiMapRecord | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ContainsEntryOperation | 
| class  | CountOperation | 
| class  | EntrySetOperation | 
| class  | EntrySetResponse | 
| class  | GetAllOperation | 
| class  | KeySetOperation | 
| class  | MultiMapBackupAwareOperation | 
| class  | MultiMapKeyBasedOperation | 
| class  | MultiMapMigrationOperation | 
| class  | MultiMapOperation | 
| class  | MultiMapOperationFactory | 
| class  | MultiMapResponse | 
| class  | PutBackupOperation | 
| class  | PutOperation | 
| class  | RemoveAllBackupOperation | 
| class  | RemoveAllOperation | 
| class  | ValuesOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MultiMapTransactionLogRecord | 
| class  | TxnCommitBackupOperation | 
| class  | TxnCommitOperation | 
| 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 | Interface and Description | 
|---|---|
| interface  | IdentifiedDataSerializableIdentifiedDataSerializable is an extension to  DataSerializableto avoid reflection during de-serialization. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | InternalPartitionLostEventInternal event that is dispatched to @see com.hazelcast.spi.PartitionAwareService#onPartitionLost()
 
 It contains the partition id, number of replicas that is lost and the address of node that detects the partition lost | 
| class  | MigrationInfo | 
| class  | PartitionLostEventThe event that is fired when a partition lost its owner and all backups. | 
| class  | PartitionRuntimeState | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PartitionsResponse | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AssignPartitions | 
| class  | BaseMigrationOperation | 
| class  | CheckReplicaVersion | 
| class  | HasOngoingMigration | 
| class  | IsReplicaVersionSyncQueries if replica version is sync between partitions. | 
| class  | MigrationOperation | 
| class  | MigrationRequestOperation | 
| class  | PartitionStateOperation | 
| class  | ReplicaSyncRequest | 
| class  | ReplicaSyncResponse | 
| class  | ReplicaSyncRetryResponse | 
| class  | SafeStateCheckOperationChecks whether a node is safe or not. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PagingPredicateThis class is a special Predicate which helps to get a page-by-page result of a query. | 
| class  | PredicateBuilderThis class provides functionality to build predicate. | 
| class  | SqlPredicateThis class contains methods related to conversion of sql query to predicate. | 
| class  | TruePredicateA  Predicatewhich always returns true. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FalsePredicatereminder:
 when FalsePredicate is going to implement IdentifiedDataSerializable, make sure no new instance
 is created, but the INSTANCE is returned. | 
| static class  | IndexImpl.NullObject | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractIndexAwarePredicate | 
| class  | AbstractPredicateProvides base features for predicates, such as extraction and convertion 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  | AbstractReplicatedMapOperation | 
| class  | ClearLocalAndRemoteOperation | 
| class  | ClearLocalOperationThis operation will execute the remote clear on replicated map if
  ReplicatedMap.clear()is called. | 
| 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> | 
| class  | ReplicatedRecord<K,V>A ReplicatedRecord is the actual data holding entity. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ReplicatedMapMergePolicyA policy for merging replicated maps after a split-brain was detected and the different network partitions need
 to be merged. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReadResultSetImpl<E>A list for the  ReadManyOperation. | 
| class  | RingbufferContainerThe RingbufferContainer is responsible for storing the actual content of a ringbuffer. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractRingBufferOperation | 
| class  | AddAllBackupOperation | 
| class  | AddAllOperation | 
| class  | AddBackupOperation | 
| class  | AddOperation | 
| class  | GenericOperation | 
| class  | ReadManyOperation | 
| class  | ReadOneOperation | 
| class  | ReplicationOperation | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | EventRegistrationThe result of a Event Registration. | 
| interface  | ObjectNamespaceAn ObjectNamespace that makes identification of object within a service possible. | 
| interface  | OperationFactoryA Factory for creating  Operationinstances. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractOperationAbstract  Operationimplementation with some basic methods
 implemented. | 
| class  | DefaultObjectNamespaceDefault  ObjectNamespaceimplementation. | 
| class  | MemberAttributeServiceEventThis service event is fired to inform services about a change in a member's attributes collection | 
| class  | OperationAn operation could be compared to a  Runnable. | 
| 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  | Registration | 
| class  | TrueEventFilterAn event filter which does not filter any event and always evaluates  trueresults. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DeregistrationOperation | 
| class  | PostJoinRegistrationOperation | 
| class  | RegistrationOperation | 
| class  | SendEventOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | Backup | 
| class  | IsStillExecutingOperationAn operation that checks if another operation is still running. | 
| class  | PartitionIteratingOperation | 
| static class  | PartitionIteratingOperation.PartitionResponse | 
| class  | TraceableIsStillExecutingOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BackupResponseThe {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  | DistributedObjectEventPacket | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DistributedObjectDestroyOperation | 
| class  | InitializeDistributedObjectOperation | 
| class  | PostJoinProxyOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PublishOperation | 
| class  | TopicEvent | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReliableTopicMessageThe Object that is going to be stored in the Ringbuffer. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TransactionOptionsContains the configuration for a Hazelcast transaction. | 
| 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  | BroadcastTxRollbackOperation | 
| class  | CreateAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | CreateTxBackupLogOperation | 
| class  | PurgeAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | PurgeTxBackupLogOperation | 
| class  | ReplicateAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | ReplicateTxBackupLogOperationReplicates the transactionlog to a remote system. | 
| class  | RollbackAllowedDuringPassiveStateTxBackupLogOperation | 
| class  | RollbackTxBackupLogOperation | 
| class  | TxBaseOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SerializableXID | 
| class  | XATransactionDTO | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseXAOperation | 
| class  | ClearRemoteTransactionBackupOperation | 
| class  | ClearRemoteTransactionOperation | 
| class  | CollectRemoteTransactionsOperation | 
| class  | CollectRemoteTransactionsOperationFactory | 
| class  | FinalizeRemoteTransactionBackupOperation | 
| class  | FinalizeRemoteTransactionOperation | 
| class  | PutRemoteTransactionBackupOperation | 
| class  | PutRemoteTransactionOperation | 
| class  | XaReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | WanReplicationEventEvent class used to transmit the actual event object | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SessionStateWrapper class which holds session attributes and jvmIds | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DeleteSessionEntryProcessorEntry processor which removes SessionState values if
 invalidate is true. | 
| class  | GetAttributeEntryProcessorEntry processor which return attributes of SessionState values and
 adds current jvmId into SessionState. | 
| class  | GetAttributeNamesEntryProcessorEntry processor which return attributes keySet of SessionState values and
 adds current jvmId into SessionState. | 
| class  | GetSessionStateEntryProcessorEntry processor which return SessionState object stored in distributed map and
 adds current jvmId into SessionState. | 
| class  | SessionUpdateEntryProcessorEntry processor which updates SessionState attributes stored in distributed map and
 adds current jvmId into SessionState If value of attribute is set to null. | 
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.