| Package | Description | 
|---|---|
| com.hazelcast.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.client.impl | Contains most of the client side HazelcastInstance implementation 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.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.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.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.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.eviction | This package contains eviction classes. | 
| com.hazelcast.map.impl.proxy | Contains map proxy implementation and support classes. | 
| com.hazelcast.map.impl.tx | Contains implementation classes for  TransactionalMap | 
| 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.partition.impl | Contains the actual implementation of the  InternalPartitionService. | 
| com.hazelcast.queue.impl | This package contains the IQueue functionality. The IQueueis the distributed version of theBlockingQueue. | 
| 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.record | This package contains the implementation of the backing data storage for the replicated map implementation | 
| com.hazelcast.spi | Provides interfaces/classes for Hazelcast SPI. | 
| com.hazelcast.spi.impl | Contains implementations for Hazelcast SPI. | 
| com.hazelcast.topic.impl | This package contains ITopic functionality for Hazelcast. With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. | 
| com.hazelcast.transaction.impl | Provides implementation for Hazelcast transaction support. | 
| com.hazelcast.util.executor | This package contains classes related to Util.Executor  | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NodeEngine | AbstractCacheService. nodeEngine | 
| protected NodeEngine | AbstractCacheRecordStore. nodeEngine | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | AbstractCacheService. getNodeEngine() | 
| NodeEngine | ICacheService. getNodeEngine() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected static int | CacheProxyUtil. getPartitionId(NodeEngine nodeEngine,
              Data key) | 
| void | AbstractCacheService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| AbstractCacheRecordStore(String name,
                        int partitionId,
                        NodeEngine nodeEngine,
                        AbstractCacheService cacheService) | 
| CacheDistributedObject(String name,
                      NodeEngine nodeEngine,
                      ICacheService service) | 
| CacheProxy(CacheConfig cacheConfig,
          NodeEngine nodeEngine,
          ICacheService cacheService,
          HazelcastServerCacheManager cacheManager) | 
| CacheRecordStore(String name,
                int partitionId,
                NodeEngine nodeEngine,
                AbstractCacheService cacheService) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ClientEngineImpl. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| ClientEndpointManagerImpl(ClientEngineImpl clientEngine,
                         NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ClusterServiceImpl. init(NodeEngine nodeEngine,
    Properties properties) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NodeEngine | CollectionService. nodeEngine | 
| protected NodeEngine | CollectionContainer. nodeEngine | 
| Modifier and Type | Method and Description | 
|---|---|
| protected abstract CollectionConfig | AbstractCollectionProxyImpl. getConfig(NodeEngine nodeEngine) | 
| void | CollectionContainer. init(NodeEngine nodeEngine) | 
| void | CollectionService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| AbstractCollectionProxyImpl(String name,
                           NodeEngine nodeEngine,
                           S service) | 
| CollectionContainer(String name,
                   NodeEngine nodeEngine) | 
| CollectionService(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected CollectionConfig | ListProxyImpl. getConfig(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| ListContainer(String name,
             NodeEngine nodeEngine) | 
| ListProxyImpl(String name,
             NodeEngine nodeEngine,
             ListService service) | 
| ListService(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected CollectionConfig | SetProxyImpl. getConfig(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| SetContainer(String name,
            NodeEngine nodeEngine) | 
| SetProxyImpl(String name,
            NodeEngine nodeEngine,
            SetService service) | 
| SetService(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| Future | CollectionTransactionLog. commit(NodeEngine nodeEngine) | 
| Future | CollectionTransactionLog. prepare(NodeEngine nodeEngine) | 
| Future | CollectionTransactionLog. rollback(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| AbstractTransactionalCollectionProxy(String name,
                                    TransactionSupport tx,
                                    NodeEngine nodeEngine,
                                    S service) | 
| TransactionalListProxy(String name,
                      TransactionSupport tx,
                      NodeEngine nodeEngine,
                      ListService service) | 
| TransactionalSetProxy(String name,
                     TransactionSupport tx,
                     NodeEngine nodeEngine,
                     SetService service) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AtomicLongService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| AtomicLongProxy(String name,
               NodeEngine nodeEngine,
               AtomicLongService service) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AtomicReferenceService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| AtomicReferenceProxy(String name,
                    NodeEngine nodeEngine,
                    AtomicReferenceService service) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CountDownLatchService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| CountDownLatchProxy(String name,
                   NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | IdGeneratorService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| IdGeneratorProxy(IAtomicLong blockGenerator,
                String name,
                NodeEngine nodeEngine,
                IdGeneratorService service) | 
| IdGeneratorService(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LockProxySupport. forceUnlock(NodeEngine nodeEngine,
           Data key) | 
| int | LockProxySupport. getLockCount(NodeEngine nodeEngine,
            Data key) | 
| long | LockProxySupport. getRemainingLeaseTime(NodeEngine nodeEngine,
                     Data key) | 
| void | LockServiceImpl. init(NodeEngine nodeEngine,
    Properties properties) | 
| boolean | LockProxySupport. isLocked(NodeEngine nodeEngine,
        Data key) | 
| boolean | LockProxySupport. isLockedByCurrentThread(NodeEngine nodeEngine,
                       Data key) | 
| void | LockProxySupport. lock(NodeEngine nodeEngine,
    Data key) | 
| void | LockProxySupport. lock(NodeEngine nodeEngine,
    Data key,
    long ttl) | 
| void | LockProxySupport. lockInterruptly(NodeEngine nodeEngine,
               Data key) | 
| void | LockProxySupport. lockInterruptly(NodeEngine nodeEngine,
               Data key,
               long ttl) | 
| boolean | LockProxySupport. tryLock(NodeEngine nodeEngine,
       Data key) | 
| boolean | LockProxySupport. tryLock(NodeEngine nodeEngine,
       Data key,
       long timeout,
       TimeUnit timeunit) | 
| void | LockProxySupport. unlock(NodeEngine nodeEngine,
      Data key) | 
| Constructor and Description | 
|---|
| LockEvictionProcessor(NodeEngine nodeEngine,
                     ObjectNamespace namespace) | 
| LockProxy(NodeEngine nodeEngine,
         LockServiceImpl lockService,
         String name) | 
| LockServiceImpl(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SemaphoreService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| SemaphoreProxy(String name,
              SemaphoreService service,
              NodeEngine nodeEngine) | 
| SemaphoreService(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DistributedExecutorService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| ExecutorServiceProxy(String name,
                    NodeEngine nodeEngine,
                    DistributedExecutorService service) | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | MapServiceContext. getNodeEngine() | 
| NodeEngine | DefaultMapServiceContext. getNodeEngine() | 
| Modifier and Type | Method and Description | 
|---|---|
| static MapService | MapService. create(NodeEngine nodeEngine)Static factory method which creates a new map service object. | 
| void | MapService. init(NodeEngine nodeEngine,
    Properties properties) | 
| void | MapContainer. initWanReplication(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| DefaultMapServiceContext(NodeEngine nodeEngine) | 
| LocalMapStatsProvider(MapServiceContext mapServiceContext,
                     NodeEngine nodeEngine) | 
| NearCache(String mapName,
         NodeEngine nodeEngine) | 
| NearCacheProvider(MapServiceContext mapServiceContext,
                 NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| ExpirationManager(MapServiceContext mapServiceContext,
                 NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| MapProxyImpl(String name,
            MapService mapService,
            NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| Future | MapTransactionLog. commit(NodeEngine nodeEngine) | 
| Future | MapTransactionLog. prepare(NodeEngine nodeEngine) | 
| Future | MapTransactionLog. rollback(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| TransactionalMapProxy(String name,
                     MapService mapService,
                     NodeEngine nodeEngine,
                     TransactionSupport transaction) | 
| TransactionalMapProxySupport(String name,
                            MapService mapService,
                            NodeEngine nodeEngine,
                            TransactionSupport transaction) | 
| Constructor and Description | 
|---|
| MergePolicyProvider(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract boolean | KeyValueSource. open(NodeEngine nodeEngine)This method is called before accessing the key-value pairs of this KeyValueSource | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NodeEngine | AbstractJobTracker. nodeEngine | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | MapReduceService. getNodeEngine() | 
| Modifier and Type | Method and Description | 
|---|---|
| static <V> V | MapReduceUtil. executeOperation(Operation operation,
                Address address,
                MapReduceService mapReduceService,
                NodeEngine nodeEngine) | 
| static <V> List<V> | MapReduceUtil. executeOperation(OperationFactory operationFactory,
                MapReduceService mapReduceService,
                NodeEngine nodeEngine,
                boolean returnsResponse) | 
| void | MapReduceService. init(NodeEngine nodeEngine,
    Properties properties) | 
| static void | MapReduceUtil. injectManagedContext(NodeEngine nodeEngine,
                    Object injectee,
                    Object... injectees) | 
| boolean | MultiMapKeyValueSource. open(NodeEngine nodeEngine) | 
| boolean | MapKeyValueSource. open(NodeEngine nodeEngine) | 
| boolean | SetKeyValueSource. open(NodeEngine nodeEngine) | 
| boolean | ListKeyValueSource. open(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| MapReduceService(NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | JobTaskConfiguration. getNodeEngine() | 
| Constructor and Description | 
|---|
| JobTaskConfiguration(Address jobOwner,
                    NodeEngine nodeEngine,
                    int chunkSize,
                    String name,
                    String jobId,
                    Mapper mapper,
                    CombinerFactory combinerFactory,
                    ReducerFactory reducerFactory,
                    KeyValueSource keyValueSource,
                    boolean communicateStats,
                    TopologyChangedStrategy topologyChangedStrategy) | 
| KeyValueJob(String name,
           AbstractJobTracker jobTracker,
           NodeEngine nodeEngine,
           MapReduceService mapReduceService,
           KeyValueSource<KeyIn,ValueIn> keyValueSource) | 
| TrackableJobFuture(String name,
                  String jobId,
                  JobTracker jobTracker,
                  NodeEngine nodeEngine,
                  Collator collator) | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | MultiMapService. getNodeEngine() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MultiMapService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| MultiMapEventsPublisher(NodeEngine nodeEngine) | 
| MultiMapProxySupport(MultiMapService service,
                    NodeEngine nodeEngine,
                    String name) | 
| MultiMapService(NodeEngine nodeEngine) | 
| ObjectMultiMapProxy(MultiMapService service,
                   NodeEngine nodeEngine,
                   String name) | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection | MultiMapResponse. getObjectCollection(NodeEngine nodeEngine) | 
| <K,V> Set<Map.Entry<K,V>> | EntrySetResponse. getObjectEntrySet(NodeEngine nodeEngine) | 
| Collection<MultiMapRecord> | MultiMapResponse. getRecordCollection(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| EntrySetResponse(Map<Data,Collection<MultiMapRecord>> map,
                NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| Future | MultiMapTransactionLog. commit(NodeEngine nodeEngine) | 
| Future | MultiMapTransactionLog. prepare(NodeEngine nodeEngine) | 
| Future | MultiMapTransactionLog. rollback(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| TransactionalMultiMapProxy(NodeEngine nodeEngine,
                          MultiMapService service,
                          String name,
                          TransactionSupport tx) | 
| TransactionalMultiMapProxySupport(NodeEngine nodeEngine,
                                 MultiMapService service,
                                 String name,
                                 TransactionSupport tx) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | InternalPartitionServiceImpl. init(NodeEngine nodeEngine,
    Properties properties) | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | QueueService. getNodeEngine() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueueService. init(NodeEngine nodeEngine,
    Properties properties) | 
| void | QueueContainer. setConfig(QueueConfig config,
         NodeEngine nodeEngine,
         QueueService service) | 
| Constructor and Description | 
|---|
| QueueContainer(String name,
              QueueConfig config,
              NodeEngine nodeEngine,
              QueueService service) | 
| QueueEvictionProcessor(NodeEngine nodeEngine,
                      QueueService service) | 
| QueueService(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| QueueProxyImpl(String name,
              QueueService queueService,
              NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| Future | QueueTransactionLog. commit(NodeEngine nodeEngine) | 
| Future | QueueTransactionLog. prepare(NodeEngine nodeEngine) | 
| Future | QueueTransactionLog. rollback(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| TransactionalQueueProxy(NodeEngine nodeEngine,
                       QueueService service,
                       String name,
                       TransactionSupport tx) | 
| TransactionalQueueProxySupport(NodeEngine nodeEngine,
                              QueueService service,
                              String name,
                              TransactionSupport tx) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicatedMapService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| ReplicatedMapEvictionProcessor(NodeEngine nodeEngine,
                              ReplicatedMapService replicatedMapService,
                              String mapName) | 
| ReplicatedMapService(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| AbstractReplicatedRecordStore(String name,
                             NodeEngine nodeEngine,
                             ReplicatedMapService replicatedMapService) | 
| DataReplicatedRecordStore(String name,
                         NodeEngine nodeEngine,
                         ReplicatedMapService replicatedMapService) | 
| ObjectReplicatedRecordStorage(String name,
                             NodeEngine nodeEngine,
                             ReplicatedMapService replicatedMapService) | 
| Modifier and Type | Method and Description | 
|---|---|
| NodeEngine | AbstractDistributedObject. getNodeEngine()Gets the node engine. | 
| NodeEngine | Operation. getNodeEngine() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ManagedService. init(NodeEngine nodeEngine,
    Properties properties)Initializes this ManagedService | 
| Operation | Operation. setNodeEngine(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| AbstractDistributedObject(NodeEngine nodeEngine,
                         S service) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NodeEngineImpl | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NodeEngine | AbstractCompletableFuture. nodeEngine | 
| Modifier and Type | Method and Description | 
|---|---|
| static ResponseHandler | ResponseHandlerFactory. createRemoteResponseHandler(NodeEngine nodeEngine,
                           RemotePropagatable remotePropagatable) | 
| static void | ResponseHandlerFactory. setRemoteResponseHandler(NodeEngine nodeEngine,
                        RemotePropagatable remotePropagatable) | 
| Constructor and Description | 
|---|
| AbstractCompletableFuture(NodeEngine nodeEngine,
                         ILogger logger) | 
| BinaryOperationFactory(Operation operation,
                      NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TopicService. init(NodeEngine nodeEngine,
    Properties properties) | 
| Constructor and Description | 
|---|
| TopicProxy(String name,
          NodeEngine nodeEngine,
          TopicService service) | 
| TotalOrderedTopicProxy(String name,
                      NodeEngine nodeEngine,
                      TopicService service) | 
| Modifier and Type | Method and Description | 
|---|---|
| Future | TransactionLog. commit(NodeEngine nodeEngine) | 
| void | TransactionManagerServiceImpl. init(NodeEngine nodeEngine,
    Properties properties) | 
| Future | TransactionLog. prepare(NodeEngine nodeEngine) | 
| Future | TransactionLog. rollback(NodeEngine nodeEngine) | 
| Constructor and Description | 
|---|
| CachedExecutorServiceDelegate(NodeEngine nodeEngine,
                             String name,
                             ExecutorService cachedExecutor,
                             int maxPoolSize,
                             int queueCapacity) | 
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.