| 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.client | Contains classes/interfaces related to Client | 
| com.hazelcast.client.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation client side | 
| com.hazelcast.client.config | Contains classes related to config for com.hazelcast.client | 
| com.hazelcast.client.connection.nio | Contains classes related to New IO for com.hazelcast.client.connection | 
| com.hazelcast.client.console | This package contains ClientConsoleApp | 
| com.hazelcast.client.impl | Contains most of the client side HazelcastInstance implementation functionality. | 
| com.hazelcast.client.impl.exceptionconverters | Contains logic to convert client exceptions. | 
| com.hazelcast.client.proxy | This package contains client side proxy implementations of the different Hazelcast data structures
 and operation types | 
| com.hazelcast.client.spi | Contains classes/interfaces related to Service Provider Interface
 such as ClientProxy , ClientClusterService | 
| com.hazelcast.client.spi.impl | Provides util classes for com.hazelcast.client | 
| com.hazelcast.client.txn | Contains classes related to Txn
 such as TransactionProxy | 
| com.hazelcast.client.txn.proxy | Contains classes related to proxy for com.hazelcast.client.client.txn | 
| com.hazelcast.client.util | This package contains some utility classes and the base implementations of the
 loadbalancer implementations | 
| 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.collection | This package contains classes related to Collections (IList,ISet etc..)  | 
| com.hazelcast.collection.common | This package contains common classes related to all collections | 
| com.hazelcast.collection.list | This package contains IList functionality for Hazelcast. | 
| com.hazelcast.collection.set | This package contains ISet functionality for Hazelcast. | 
| com.hazelcast.collection.txn | This package contains the Transaction behavior for the Collections. | 
| com.hazelcast.concurrent.atomiclong | This package contains IAtomicLong functionality for Hazelcast. The IAtomicLong is the distributed version of the AtomicLong. | 
| com.hazelcast.concurrent.atomiclong.client | This package contains client requests for the IAtomicLong. This package contains all the client request object to operate on the IAtomicLong that are send by the client. | 
| com.hazelcast.concurrent.atomiclong.operations | This package contains the operations on the IAtomicLong. | 
| com.hazelcast.concurrent.atomicreference | This package contains IAtomicReferece functionality for Hazelcast. The IAtomicReference is the distributed version of the AtomicReference. | 
| com.hazelcast.concurrent.countdownlatch | This package contains ICountDownLatch functionality for Hazelcast. The ICountDownLatch is the distributed version of the CountDownLatch. | 
| com.hazelcast.concurrent.idgen | This package contains IdGenerator functionality for Hazelcast. With the IdGeneratorit is very simple to create cluster wide id's. | 
| com.hazelcast.concurrent.lock | |
| com.hazelcast.concurrent.semaphore | This package contains ISemaphore functionality for Hazelcast. The ISemaphore is the distributed version of the Semaphore. | 
| 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.hibernate | Contains interfaces/classes related to Hibernate. | 
| com.hazelcast.hibernate.distributed | Provides distributed class for Hibernate. | 
| com.hazelcast.hibernate.instance | Provides instance interfaces/classes for Hibernate. | 
| com.hazelcast.hibernate.local | Provides local classes for Hibernate. | 
| com.hazelcast.hibernate.region | Provides region interfaces/classes for Hibernate. | 
| com.hazelcast.instance | This package contains Hazelcast Instance functionality. | 
| com.hazelcast.jca | This package contains jca functionality | 
| com.hazelcast.jmx | Contains Hazelcast management bean classes. | 
| com.hazelcast.logging | This package contains logging functionality for Hazelcast. Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs logging, so that different logging frameworks like log4j, can be hooked in. | 
| com.hazelcast.management | Contains classes to provide data/operation interface for Management Center. | 
| com.hazelcast.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.operation | Package for map operations. | 
| com.hazelcast.map.impl.proxy | Contains map proxy implementation and support classes. | 
| com.hazelcast.map.impl.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 | This package contains the MapReduce API definition for Hazelcast. All map reduce operations running in a distributed manner inside the active Hazelcast cluster. | 
| com.hazelcast.mapreduce.impl | This package contains the default implementation for the map reduce framework
 internals. | 
| 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.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.impl | Contains the actual implementation of the  InternalPartitionService. | 
| com.hazelcast.partition.membergroup | todo | 
| com.hazelcast.partition.strategy | Packages contains different partitioning strategies. | 
| com.hazelcast.query | Contains interfaces/classes related to Hazelcast query and indexing support. | 
| com.hazelcast.queue.impl | This package contains the IQueue functionality. The IQueueis the distributed version of theBlockingQueue. | 
| com.hazelcast.queue.impl.operations | This package contains the IQueue operations | 
| com.hazelcast.queue.impl.proxy | This package contains the IQueue proxies. | 
| com.hazelcast.queue.impl.tx | This package contains the Transaction behavior for the IQueue. | 
| com.hazelcast.replicatedmap.impl | This package contains the implementation of the replicated map service itself and some connection interfaces only used
 internally - No public API! | 
| com.hazelcast.replicatedmap.impl.client | This package contains classes for client communication on replicated map implementation | 
| com.hazelcast.replicatedmap.impl.messages | This package contains replication event classes to communicate replications to other nodes | 
| com.hazelcast.replicatedmap.impl.operation | This package contains some remote operations to execute 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.security | Provides interfaces/classes for Hazelcast security implementation. | 
| com.hazelcast.spi | Provides interfaces/classes for Hazelcast SPI. | 
| com.hazelcast.spi.exception | Contains exceptions for Hazelcast SPI. | 
| com.hazelcast.spi.impl | Contains implementations for Hazelcast SPI. | 
| com.hazelcast.spring.cache | Contains Hazelcast cache classes related to Spring. | 
| com.hazelcast.spring.context | Contains context classes for Spring. | 
| com.hazelcast.topic.impl | This package contains ITopic functionality for Hazelcast. With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. | 
| com.hazelcast.transaction | Provides interfaces/classes for Hazelcast transaction support. | 
| com.hazelcast.util.executor | This package contains classes related to Util.Executor  | 
| Class and Description | 
|---|
| HazelcastInstance Hazelcast instance. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| HazelcastInstance Hazelcast instance. | 
| Class and Description | 
|---|
| Cluster Hazelcast cluster interface. | 
| HazelcastException Base Hazelcast exception. | 
| HazelcastInstance Hazelcast instance. | 
| Member Cluster member interface. | 
| OutOfMemoryHandler Handler for  OutOfMemoryError. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| HazelcastInstance Hazelcast instance. | 
| Class and Description | 
|---|
| ManagedContext Container managed context, such as Spring, Guice and etc. | 
| Class and Description | 
|---|
| LifecycleService LifecycleService allows you to shutdown, terminate, and listen to  LifecycleEvent's
 on HazelcastInstance. | 
| Class and Description | 
|---|
| EntryEvent Map Entry event. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| HazelcastInstance Hazelcast instance. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ItemEvent Map Item event. | 
| ItemListener | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| MapEvent Used for map-wide events like  EntryEventType.EVICT_ALLandEntryEventType.CLEAR_ALL. | 
| Message Message for  ITopic. | 
| MessageListener Message listener for  ITopic. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| Class and Description | 
|---|
| Client The Client interface allows to get information about
 a connected client's socket address, type and uuid. | 
| ClientListener The ClientListener provides the ability to listen to clients connecting and disconnecting from the cluster. | 
| ClientService ClientService allows you to query connected  Clients and
 attach/detachClientListeners to listen to connection events. | 
| ClientType Type of a client. | 
| Cluster Hazelcast cluster interface. | 
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| Endpoint Endpoint represents a peer in the cluster. | 
| HazelcastInstance Hazelcast instance. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| IdGenerator The IdGenerator is responsible for creating unique ids (a  long) in a cluster. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| ILock Distributed implementation of  Lock. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| LifecycleService LifecycleService allows you to shutdown, terminate, and listen to  LifecycleEvent's
 on HazelcastInstance. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| PartitionService PartitionService allows you to query  Partitions and attach/detachMigrationListeners to listen to partition
 migration events. | 
| ReplicatedMap A ReplicatedMap is a map-like data structure with non-strong consistency
 (so-called eventually consistent) and values locally stored on every
 node of the cluster. | 
| Class and Description | 
|---|
| ClientType Type of a client. | 
| Class and Description | 
|---|
| BaseMap Base interface for Hazelcast distributed maps. | 
| BaseMultiMap Base interface for Hazelcast distributed multi-maps. | 
| BaseQueue Base interface for Hazelcast distributed queues. | 
| Cluster Hazelcast cluster interface. | 
| DistributedObject Base interface for all distributed objects. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| EntryView EntryView represents a readonly view of a map entry. | 
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| ICollection Concurrent, distributed, partitioned, listenable collection. | 
| ICondition Distributed implementation of  Condition. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| IdGenerator The IdGenerator is responsible for creating unique ids (a  long) in a cluster. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| IFunction Represents a function that accepts one argument and produces a result. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| ILock Distributed implementation of  Lock. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ItemListener | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| Member Cluster member interface. | 
| MemberSelector Implementations of this interface select members
 that are capable of executing a special kind of task. The MemberSelector.select(Member)method is called for every available
 member in the cluster and it is up to the implementation to decide
 if the member is going to be used or not. | 
| MembershipListener Cluster membership listener. | 
| MessageListener Message listener for  ITopic. | 
| MultiExecutionCallback MultiExecutionCallback provides notification for when an execution is completed on each member
 that a task is submitted to. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| ReplicatedMap A ReplicatedMap is a map-like data structure with non-strong consistency
 (so-called eventually consistent) and values locally stored on every
 node of the cluster. | 
| Class and Description | 
|---|
| Client The Client interface allows to get information about
 a connected client's socket address, type and uuid. | 
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| HazelcastInstance Hazelcast instance. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| MembershipListener Cluster membership listener. | 
| Partition In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
 GroupProperty. | 
| Class and Description | 
|---|
| Client The Client interface allows to get information about
 a connected client's socket address, type and uuid. | 
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| MembershipListener Cluster membership listener. | 
| Partition In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
 GroupProperty. | 
| Class and Description | 
|---|
| TransactionalList Transactional implementation of  IList. | 
| TransactionalMap Transactional implementation of  BaseMap. | 
| TransactionalMultiMap Transactional implementation of  BaseMultiMap. | 
| TransactionalQueue Transactional implementation of  BaseQueue. | 
| TransactionalSet Transactional implementation of  ISet. | 
| Class and Description | 
|---|
| BaseMap Base interface for Hazelcast distributed maps. | 
| BaseMultiMap Base interface for Hazelcast distributed multi-maps. | 
| BaseQueue Base interface for Hazelcast distributed queues. | 
| DistributedObject Base interface for all distributed objects. | 
| TransactionalList Transactional implementation of  IList. | 
| TransactionalMap Transactional implementation of  BaseMap. | 
| TransactionalMultiMap Transactional implementation of  BaseMultiMap. | 
| TransactionalQueue Transactional implementation of  BaseQueue. | 
| TransactionalSet Transactional implementation of  ISet. | 
| Class and Description | 
|---|
| Cluster Hazelcast cluster interface. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| Member Cluster member interface. | 
| MemberAttributeEvent | 
| MembershipEvent Membership event fired when a new member is added
 to the cluster and/or when a member leaves the cluster. | 
| MembershipListener Cluster membership listener. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| Class and Description | 
|---|
| Cluster Hazelcast cluster interface. | 
| HazelcastException Base Hazelcast exception. | 
| Member Cluster member interface. | 
| MembershipEvent Membership event fired when a new member is added
 to the cluster and/or when a member leaves the cluster. | 
| MembershipListener Cluster membership listener. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ItemEventType Type of item event. | 
| ItemListener | 
| Class and Description | 
|---|
| ItemEvent Map Item event. | 
| ItemEventType Type of item event. | 
| Member Cluster member interface. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ICollection Concurrent, distributed, partitioned, listenable collection. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ICollection Concurrent, distributed, partitioned, listenable collection. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| TransactionalList Transactional implementation of  IList. | 
| TransactionalSet Transactional implementation of  ISet. | 
| Class and Description | 
|---|
| AsyncAtomicLong This interface is an  IAtomicLonginterface that exposes its operations using anICompletableFutureinterface so it can be used in the reactive programming model
 approach. | 
| DistributedObject Base interface for all distributed objects. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IFunction Represents a function that accepts one argument and produces a result. | 
| Class and Description | 
|---|
| IFunction Represents a function that accepts one argument and produces a result. | 
| Class and Description | 
|---|
| IFunction Represents a function that accepts one argument and produces a result. | 
| Class and Description | 
|---|
| AsyncAtomicReference A  IAtomicReferencethat exposes its operations using aICompletableFutureso it can be used in the reactive programming model approach. | 
| DistributedObject Base interface for all distributed objects. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| IFunction Represents a function that accepts one argument and produces a result. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IdGenerator The IdGenerator is responsible for creating unique ids (a  long) in a cluster. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ICondition Distributed implementation of  Condition. | 
| ILock Distributed implementation of  Lock. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| Class and Description | 
|---|
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| ItemListener | 
| ManagedContext Container managed context, such as Spring, Guice and etc. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| QueueStore QueueStore makes a queue backed by a central data store; such as database, disk, etc. | 
| QueueStoreFactory | 
| Class and Description | 
|---|
| EntryEvent Map Entry event. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| HazelcastInstance Hazelcast instance. | 
| HazelcastInstanceAware Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ItemEvent Map Item event. | 
| ItemListener | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| MapEvent Used for map-wide events like  EntryEventType.EVICT_ALLandEntryEventType.CLEAR_ALL. | 
| Message Message for  ITopic. | 
| MessageListener Message listener for  ITopic. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| Class and Description | 
|---|
| AbstractIMapEvent The abstract class for a map event  IMapEvent. | 
| BaseMap Base interface for Hazelcast distributed maps. | 
| BaseMultiMap Base interface for Hazelcast distributed multi-maps. | 
| BaseQueue Base interface for Hazelcast distributed queues. | 
| Client The Client interface allows to get information about
 a connected client's socket address, type and uuid. | 
| ClientListener The ClientListener provides the ability to listen to clients connecting and disconnecting from the cluster. | 
| ClientService ClientService allows you to query connected  Clients and
 attach/detachClientListeners to listen to connection events. | 
| ClientType Type of a client. | 
| Cluster Hazelcast cluster interface. | 
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectEvent DistributedObjectEvent is fired when a  DistributedObjectis created or destroyed cluster-wide. | 
| DistributedObjectEvent.EventType Type of event. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| Endpoint Endpoint represents a peer in the cluster. | 
| EntryEvent Map Entry event. | 
| EntryEventType Type of entry event. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| EntryView EntryView represents a readonly view of a map entry. | 
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| HazelcastException Base Hazelcast exception. | 
| HazelcastInstance Hazelcast instance. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| ICollection Concurrent, distributed, partitioned, listenable collection. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| ICondition Distributed implementation of  Condition. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| IdGenerator The IdGenerator is responsible for creating unique ids (a  long) in a cluster. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| IFunction Represents a function that accepts one argument and produces a result. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| ILock Distributed implementation of  Lock. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IMapEvent Map events common contract. | 
| InitialMembershipEvent A event that is send when a  InitialMembershipListenerregisters itself on aCluster. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ItemEvent Map Item event. | 
| ItemEventType Type of item event. | 
| ItemListener | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| LifecycleEvent Lifecycle event fired when HazelcastInstance's state changes. | 
| LifecycleEvent.LifecycleState lifecycle states | 
| LifecycleListener Listener object for listening to lifecycle events of the Hazelcast instance | 
| LifecycleService LifecycleService allows you to shutdown, terminate, and listen to  LifecycleEvent's
 on HazelcastInstance. | 
| MapEvent Used for map-wide events like  EntryEventType.EVICT_ALLandEntryEventType.CLEAR_ALL. | 
| MapLoader Hazelcast distributed map implementation is an in-memory data store but
 it can be backed by any type of data store such as RDBMS, OODBMS, or simply
 a file based data store. | 
| MapStore Hazelcast distributed map implementation is an in-memory data store, but
 it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply
 a file-based data store. | 
| Member Cluster member interface. | 
| MemberAttributeEvent | 
| MemberSelector Implementations of this interface select members
 that are capable of executing a special kind of task. The MemberSelector.select(Member)method is called for every available
 member in the cluster and it is up to the implementation to decide
 if the member is going to be used or not. | 
| MembershipEvent Membership event fired when a new member is added
 to the cluster and/or when a member leaves the cluster. | 
| MembershipListener Cluster membership listener. | 
| Message Message for  ITopic. | 
| MessageListener Message listener for  ITopic. | 
| MigrationEvent An event fired when a partition migration starts, completes or fails. | 
| MigrationEvent.MigrationStatus Migration status: Started, completed or failed | 
| MigrationListener MigrationListener provides the ability to listen to partition migration events. | 
| MultiExecutionCallback MultiExecutionCallback provides notification for when an execution is completed on each member
 that a task is submitted to. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| OutOfMemoryHandler Handler for  OutOfMemoryError. | 
| Partition In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
 GroupProperty. | 
| PartitionAware PartitionAware means that data will be based in the same member based on the partition key
 and implementing tasks will be executed on the  PartitionAware.getPartitionKey()'s owner member. | 
| PartitionService PartitionService allows you to query  Partitions and attach/detachMigrationListeners to listen to partition
 migration events. | 
| QueueStore QueueStore makes a queue backed by a central data store; such as database, disk, etc. | 
| ReplicatedMap A ReplicatedMap is a map-like data structure with non-strong consistency
 (so-called eventually consistent) and values locally stored on every
 node of the cluster. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| HazelcastInstance Hazelcast instance. | 
| HazelcastInstanceAware Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| Member Cluster member interface. | 
| MemberSelector Implementations of this interface select members
 that are capable of executing a special kind of task. The MemberSelector.select(Member)method is called for every available
 member in the cluster and it is up to the implementation to decide
 if the member is going to be used or not. | 
| MultiExecutionCallback MultiExecutionCallback provides notification for when an execution is completed on each member
 that a task is submitted to. | 
| Class and Description | 
|---|
| EntryView EntryView represents a readonly view of a map entry. | 
| HazelcastInstance Hazelcast instance. | 
| Class and Description | 
|---|
| HazelcastInstance Hazelcast instance. | 
| Class and Description | 
|---|
| HazelcastInstance Hazelcast instance. | 
| Class and Description | 
|---|
| HazelcastInstance Hazelcast instance. | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| MessageListener Message listener for  ITopic. | 
| Class and Description | 
|---|
| HazelcastInstance Hazelcast instance. | 
| Class and Description | 
|---|
| ClientService ClientService allows you to query connected  Clients and
 attach/detachClientListeners to listen to connection events. | 
| Cluster Hazelcast cluster interface. | 
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| Endpoint Endpoint represents a peer in the cluster. | 
| HazelcastInstance Hazelcast instance. | 
| HazelcastInstanceAware Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| IdGenerator The IdGenerator is responsible for creating unique ids (a  long) in a cluster. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| ILock Distributed implementation of  Lock. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| LifecycleEvent Lifecycle event fired when HazelcastInstance's state changes. | 
| LifecycleEvent.LifecycleState lifecycle states | 
| LifecycleListener Listener object for listening to lifecycle events of the Hazelcast instance | 
| LifecycleService LifecycleService allows you to shutdown, terminate, and listen to  LifecycleEvent's
 on HazelcastInstance. | 
| ManagedContext Container managed context, such as Spring, Guice and etc. | 
| Member Cluster member interface. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| OutOfMemoryHandler Handler for  OutOfMemoryError. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| PartitionService PartitionService allows you to query  Partitions and attach/detachMigrationListeners to listen to partition
 migration events. | 
| ReplicatedMap A ReplicatedMap is a map-like data structure with non-strong consistency
 (so-called eventually consistent) and values locally stored on every
 node of the cluster. | 
| Class and Description | 
|---|
| ClientService ClientService allows you to query connected  Clients and
 attach/detachClientListeners to listen to connection events. | 
| Cluster Hazelcast cluster interface. | 
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| Endpoint Endpoint represents a peer in the cluster. | 
| HazelcastInstance Hazelcast instance. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| IdGenerator The IdGenerator is responsible for creating unique ids (a  long) in a cluster. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| ILock Distributed implementation of  Lock. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| LifecycleService LifecycleService allows you to shutdown, terminate, and listen to  LifecycleEvent's
 on HazelcastInstance. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| PartitionService PartitionService allows you to query  Partitions and attach/detachMigrationListeners to listen to partition
 migration events. | 
| ReplicatedMap A ReplicatedMap is a map-like data structure with non-strong consistency
 (so-called eventually consistent) and values locally stored on every
 node of the cluster. | 
| TransactionalList Transactional implementation of  IList. | 
| TransactionalMap Transactional implementation of  BaseMap. | 
| TransactionalMultiMap Transactional implementation of  BaseMultiMap. | 
| TransactionalQueue Transactional implementation of  BaseQueue. | 
| TransactionalSet Transactional implementation of  ISet. | 
| Class and Description | 
|---|
| DistributedObjectEvent DistributedObjectEvent is fired when a  DistributedObjectis created or destroyed cluster-wide. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| HazelcastInstance Hazelcast instance. | 
| IAtomicLong IAtomicLong is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicLong. | 
| IAtomicReference IAtomicReference is a redundant and highly available distributed alternative to the
  java.util.concurrent.atomic.AtomicReference. | 
| ICountDownLatch ICountDownLatch is a backed-up distributed alternative to the
  java.util.concurrent.CountDownLatch. | 
| IExecutorService Distributed implementation of  ExecutorService. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| ILock Distributed implementation of  Lock. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| ISemaphore ISemaphore is a backed-up distributed alternative to the  Semaphore. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| Class and Description | 
|---|
| Client The Client interface allows to get information about
 a connected client's socket address, type and uuid. | 
| HazelcastInstance Hazelcast instance. | 
| Member Cluster member interface. | 
| MemberAttributeEvent | 
| MembershipEvent Membership event fired when a new member is added
 to the cluster and/or when a member leaves the cluster. | 
| MembershipListener Cluster membership listener. | 
| Class and Description | 
|---|
| AbstractIMapEvent The abstract class for a map event  IMapEvent. | 
| DistributedObject Base interface for all distributed objects. | 
| EntryEvent Map Entry event. | 
| EntryEventType Type of entry event. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| EntryView EntryView represents a readonly view of a map entry. | 
| HazelcastInstance Hazelcast instance. | 
| IMapEvent Map events common contract. | 
| MapLoader Hazelcast distributed map implementation is an in-memory data store but
 it can be backed by any type of data store such as RDBMS, OODBMS, or simply
 a file based data store. | 
| MapLoaderLifecycleSupport Provides Lifecycle support for the implementing MapLoader class. | 
| MapStore Hazelcast distributed map implementation is an in-memory data store, but
 it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply
 a file-based data store. | 
| Member Cluster member interface. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| Class and Description | 
|---|
| EntryEventType Type of entry event. | 
| EntryView EntryView represents a readonly view of a map entry. | 
| Class and Description | 
|---|
| BaseMap Base interface for Hazelcast distributed maps. | 
| DistributedObject Base interface for all distributed objects. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| EntryView EntryView represents a readonly view of a map entry. | 
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| Class and Description | 
|---|
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| Class and Description | 
|---|
| BaseMap Base interface for Hazelcast distributed maps. | 
| DistributedObject Base interface for all distributed objects. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| TransactionalMap Transactional implementation of  BaseMap. | 
| Class and Description | 
|---|
| EntryView EntryView represents a readonly view of a map entry. | 
| Class and Description | 
|---|
| EntryView EntryView represents a readonly view of a map entry. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| HazelcastException Base Hazelcast exception. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| IList Concurrent, distributed implementation of  ListThe Hazelcast IList is not a partitioned data-structure. | 
| IMap Concurrent, distributed, observable and queryable map. | 
| ISet Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| Class and Description | 
|---|
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| Class and Description | 
|---|
| BaseMultiMap Base interface for Hazelcast distributed multi-maps. | 
| DistributedObject Base interface for all distributed objects. | 
| EntryEventType Type of entry event. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| MultiMap A specialized map whose keys can be associated with multiple values. | 
| Class and Description | 
|---|
| EntryEventType Type of entry event. | 
| Class and Description | 
|---|
| BaseMultiMap Base interface for Hazelcast distributed multi-maps. | 
| DistributedObject Base interface for all distributed objects. | 
| TransactionalMultiMap Transactional implementation of  BaseMultiMap. | 
| Class and Description | 
|---|
| HazelcastException Base Hazelcast exception. | 
| HazelcastInstance Hazelcast instance. | 
| ManagedContext Container managed context, such as Spring, Guice and etc. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| MigrationListener MigrationListener provides the ability to listen to partition migration events. | 
| Partition In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
 GroupProperty. | 
| PartitionService PartitionService allows you to query  Partitions and attach/detachMigrationListeners to listen to partition
 migration events. | 
| Class and Description | 
|---|
| MigrationEvent An event fired when a partition migration starts, completes or fails. | 
| MigrationListener MigrationListener provides the ability to listen to partition migration events. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| Class and Description | 
|---|
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| Class and Description | 
|---|
| HazelcastException Base Hazelcast exception. | 
| Class and Description | 
|---|
| ItemEventType Type of item event. | 
| ItemListener | 
| QueueStore QueueStore makes a queue backed by a central data store; such as database, disk, etc. | 
| Class and Description | 
|---|
| ItemEventType Type of item event. | 
| Class and Description | 
|---|
| BaseQueue Base interface for Hazelcast distributed queues. | 
| DistributedObject Base interface for all distributed objects. | 
| ICollection Concurrent, distributed, partitioned, listenable collection. | 
| IQueue Concurrent, blocking, distributed, observable queue. | 
| Class and Description | 
|---|
| BaseQueue Base interface for Hazelcast distributed queues. | 
| DistributedObject Base interface for all distributed objects. | 
| TransactionalQueue Transactional implementation of  BaseQueue. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| ReplicatedMap A ReplicatedMap is a map-like data structure with non-strong consistency
 (so-called eventually consistent) and values locally stored on every
 node of the cluster. | 
| Class and Description | 
|---|
| EntryEventType Type of entry event. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| Class and Description | 
|---|
| Member Cluster member interface. | 
| Class and Description | 
|---|
| EntryListener Map Entry listener to get notified when a map entry
 is added, removed, updated or evicted. | 
| Member Cluster member interface. | 
| Class and Description | 
|---|
| HazelcastInstanceAware Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService. | 
| Class and Description | 
|---|
| Cluster Hazelcast cluster interface. | 
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| HazelcastInstance Hazelcast instance. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| MemberAttributeEvent | 
| MembershipEvent Membership event fired when a new member is added
 to the cluster and/or when a member leaves the cluster. | 
| PartitioningStrategy PartitioningStrategy allows keys to be located on the same member. | 
| Class and Description | 
|---|
| HazelcastException Base Hazelcast exception. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| DistributedObjectEvent.EventType Type of event. | 
| DistributedObjectListener DistributedObjectListener notifies when a  DistributedObjectis created or destroyed cluster-wide. | 
| EntryEventType Type of entry event. | 
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| HazelcastInstance Hazelcast instance. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
| ItemEventType Type of item event. | 
| Class and Description | 
|---|
| IMap Concurrent, distributed, observable and queryable map. | 
| Class and Description | 
|---|
| ManagedContext Container managed context, such as Spring, Guice and etc. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| ITopic Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. | 
| Member Cluster member interface. | 
| Message Message for  ITopic. | 
| MessageListener Message listener for  ITopic. | 
| Class and Description | 
|---|
| DistributedObject Base interface for all distributed objects. | 
| HazelcastException Base Hazelcast exception. | 
| TransactionalList Transactional implementation of  IList. | 
| TransactionalMap Transactional implementation of  BaseMap. | 
| TransactionalMultiMap Transactional implementation of  BaseMultiMap. | 
| TransactionalQueue Transactional implementation of  BaseQueue. | 
| TransactionalSet Transactional implementation of  ISet. | 
| Class and Description | 
|---|
| ExecutionCallback ExecutionCallback allows to asynchronously get notified when the execution is completed,
 either successfully or with error. | 
| ICompletableFuture A Future where one can asynchronously listen on completion. | 
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.