| Package | Description | 
|---|---|
| com.hazelcast.cache.impl | 
 
     Hazelcast JSR-107 aka JCache implementation 
 | 
| com.hazelcast.cache.impl.journal | |
| com.hazelcast.cache.impl.merge.policy | 
 This package contains merge policy internal interfaces and functionality for Hazelcast cache. 
 | 
| com.hazelcast.cardinality.impl | |
| com.hazelcast.client.impl | 
 Contains most of the client side HazelcastInstance implementation functionality. 
 | 
| com.hazelcast.client.impl.protocol | 
 Client protocol related private implementation classes 
 | 
| com.hazelcast.collection.impl.collection | |
| com.hazelcast.collection.impl.list | 
 This package contains IList functionality for Hazelcast. 
 | 
| com.hazelcast.collection.impl.queue | |
| com.hazelcast.collection.impl.set | 
 This package contains ISet functionality for Hazelcast. 
 | 
| com.hazelcast.collection.impl.txncollection | |
| com.hazelcast.collection.impl.txnlist | |
| com.hazelcast.collection.impl.txnqueue | |
| com.hazelcast.collection.impl.txnset | |
| 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. 
 | 
| 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.crdt | 
 This package contains CRDT (conflict-free replicated data type)
 implementations based on the Hazelcast infrastructure. 
 | 
| com.hazelcast.crdt.pncounter | 
 This package contains the PN (Positive-Negative) CRDT counter
 implementation. 
 | 
| com.hazelcast.durableexecutor.impl | 
 Contains the  
DurableExecutorService implementation classes. | 
| com.hazelcast.executor.impl | 
 This package contains IExecutorService functionality for Hazelcast. 
The IExecutorService extends the ExecutorService and provides all kinds
 of additional methods related to distributed systems. | 
| com.hazelcast.flakeidgen.impl | |
| com.hazelcast.internal.cluster.impl | 
 This package contains the implementation of the cluster functionality. 
 | 
| com.hazelcast.internal.dynamicconfig | 
 Classes related to Dynamic Configuration. 
 | 
| com.hazelcast.internal.nearcache.impl.invalidation | 
 Invalidations for Near Cache. 
 | 
| com.hazelcast.internal.partition.impl | 
 Contains the actual implementation of the  
InternalPartitionService. | 
| com.hazelcast.internal.usercodedeployment | 
 Module related to User Code Deployment 
 | 
| com.hazelcast.internal.usercodedeployment.impl | |
| com.hazelcast.internal.util | 
 This package contains classes to support the inner workings of Hazelcast
 as well as some backports of newer Java features / data structures to
 support older Java versions in a clean and nice way. 
 | 
| com.hazelcast.map.impl | 
 Contains implementation specific classes of  
com.hazelcast.map package. | 
| com.hazelcast.map.impl.event | |
| com.hazelcast.map.impl.eviction | 
 This package contains eviction classes. 
 | 
| com.hazelcast.map.impl.journal | |
| com.hazelcast.map.impl.nearcache | 
 Contains Near Cache specific classes. 
 | 
| 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.query | |
| com.hazelcast.map.impl.querycache.publisher | 
 This package contains classes which are used for  
QueryCache
 event publishing side. | 
| com.hazelcast.map.impl.tx | 
 Contains implementation classes for  
TransactionalMap | 
| com.hazelcast.map.merge | 
 Contains out-of-the-box 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.replicatedmap.impl | 
 This package contains the implementation of the replicated map service itself and some connection interfaces only used
 internally. 
 | 
| 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 out-of-the-box merge policies for  
ReplicatedMap. | 
| com.hazelcast.ringbuffer.impl | 
 Contains the  
Ringbuffer implementation classes. | 
| com.hazelcast.scheduledexecutor.impl | |
| com.hazelcast.spi | 
 Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services. 
 | 
| com.hazelcast.spi.impl | 
 Contains implementations for Hazelcast SPI. 
 | 
| com.hazelcast.spi.impl.merge | 
 This package contains split-brain related classes. 
 | 
| com.hazelcast.spi.impl.operationparker.impl | 
 Contains the implementation code for the  
OperationParker. | 
| com.hazelcast.spi.impl.operationservice.impl.batching | |
| com.hazelcast.spi.impl.operationservice.impl.operations | 
 Contains the Operations being used by the  
OperationServiceImpl. | 
| com.hazelcast.spi.impl.servicemanager | 
 Contains the API for the  
ServiceManager. | 
| com.hazelcast.spi.merge | 
 This package contains interfaces and classes of the split-brain merging SPI. 
 | 
| com.hazelcast.topic.impl | 
 This package contains ITopic functionality for Hazelcast. 
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics.  | 
| com.hazelcast.topic.impl.reliable | |
| com.hazelcast.transaction.impl | 
 Provides implementation for Hazelcast transaction support. 
 | 
| com.hazelcast.transaction.impl.xa | 
 Provides implementation for Hazelcast XA 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 | 
|---|---|
static int | 
CacheProxyUtil.getPartitionId(NodeEngine nodeEngine,
              Data key)  | 
void | 
AbstractCacheService.init(NodeEngine nodeEngine,
    Properties properties)  | 
void | 
AbstractCacheRecordStore.instrument(NodeEngine nodeEngine)  | 
protected void | 
AbstractCacheService.postInit(NodeEngine nodeEngine,
        Properties properties)  | 
| Constructor and Description | 
|---|
AbstractCacheRecordStore(String cacheNameWithPrefix,
                        int partitionId,
                        NodeEngine nodeEngine,
                        AbstractCacheService cacheService)  | 
CacheRecordStore(String cacheNameWithPrefix,
                int partitionId,
                NodeEngine nodeEngine,
                AbstractCacheService cacheService)  | 
| Constructor and Description | 
|---|
RingbufferCacheEventJournalImpl(NodeEngine engine)  | 
| Constructor and Description | 
|---|
CacheMergePolicyProvider(NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
CardinalityEstimatorService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ClientEngineImpl.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
ClientEndpointManagerImpl(NodeEngine nodeEngine)  | 
CompositeMessageTaskFactory(NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
DefaultMessageTaskFactoryProvider(NodeEngine nodeEngine)  | 
| 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 | 
|---|---|
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)  | 
QueueProxyImpl(String name,
              QueueService queueService,
              NodeEngine nodeEngine,
              QueueConfig config)  | 
QueueService(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)  | 
| Constructor and Description | 
|---|
AbstractTransactionalCollectionProxy(String name,
                                    Transaction tx,
                                    NodeEngine nodeEngine,
                                    S service)  | 
| Constructor and Description | 
|---|
TransactionalListProxy(String name,
                      Transaction tx,
                      NodeEngine nodeEngine,
                      ListService service)  | 
| Constructor and Description | 
|---|
TransactionalQueueProxy(NodeEngine nodeEngine,
                       QueueService service,
                       String name,
                       Transaction tx)  | 
| Constructor and Description | 
|---|
TransactionalSetProxy(String name,
                     Transaction 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 leaseTime)  | 
void | 
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
               Data key)  | 
void | 
LockProxySupport.lockInterruptly(NodeEngine nodeEngine,
               Data key,
               long leaseTime)  | 
boolean | 
LockProxySupport.tryLock(NodeEngine nodeEngine,
       Data key)  | 
boolean | 
LockProxySupport.tryLock(NodeEngine nodeEngine,
       Data key,
       long timeout,
       TimeUnit timeunit)  | 
boolean | 
LockProxySupport.tryLock(NodeEngine nodeEngine,
       Data key,
       long timeout,
       TimeUnit timeunit,
       long leaseTime,
       TimeUnit leaseTimeunit)  | 
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 | 
CRDTReplicationMigrationService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
PNCounterService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Modifier and Type | Method and Description | 
|---|---|
NodeEngine | 
DistributedDurableExecutorService.getNodeEngine()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
DistributedDurableExecutorService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| 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 | 
|---|---|
void | 
FlakeIdGeneratorService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
FlakeIdGeneratorService(NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ClusterServiceImpl.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ClusterWideConfigurationService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
ClusterWideConfigurationService(NodeEngine nodeEngine,
                               DynamicConfigListener dynamicConfigListener)  | 
Merger(NodeEngine nodeEngine,
      Operation replicationOperation)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected NodeEngine | 
Invalidator.nodeEngine  | 
| Constructor and Description | 
|---|
BatchInvalidator(String serviceName,
                int batchSize,
                int batchFrequencySeconds,
                IFunction<EventRegistration,Boolean> eventFilter,
                NodeEngine nodeEngine)  | 
Invalidator(String serviceName,
           IFunction<EventRegistration,Boolean> eventFilter,
           NodeEngine nodeEngine)  | 
NonStopInvalidator(String serviceName,
                  IFunction<EventRegistration,Boolean> eventFilter,
                  NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
InternalPartitionServiceImpl.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
UserCodeDeploymentService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
ClassLocator(ConcurrentMap<String,ClassSource> classSourceMap,
            ConcurrentMap<String,ClassSource> clientClassSourceMap,
            ClassLoader parent,
            Filter<String> classNameFilter,
            Filter<Member> memberFilter,
            UserCodeDeploymentConfig.ClassCacheMode classCacheMode,
            NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
static LocalRetryableExecution | 
InvocationUtil.executeLocallyWithRetry(NodeEngine nodeEngine,
                       Operation operation)
Constructs a local execution with retry logic. 
 | 
static ICompletableFuture<Object> | 
InvocationUtil.invokeOnStableClusterSerial(NodeEngine nodeEngine,
                           Supplier<? extends Operation> operationSupplier,
                           int maxRetries)
Invoke operation on all cluster members. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
NodeEngine | 
MapServiceContext.getNodeEngine()  | 
NodeEngine | 
MapServiceFactory.getNodeEngine()
Returns a  
NodeEngine implementation. | 
| Modifier and Type | Method and Description | 
|---|---|
static ConstructorFunction<NodeEngine,MapService> | 
MapServiceConstructor.getDefaultMapServiceConstructor()
Returns a  
Constructor which will be used to create a  MapService object. | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MapService.init(NodeEngine nodeEngine,
    Properties properties)  | 
void | 
MapManagedService.init(NodeEngine nodeEngine,
    Properties properties)  | 
void | 
MapContainer.initWanReplication(NodeEngine nodeEngine)  | 
void | 
MapStoreWrapper.instrument(NodeEngine nodeEngine)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected NodeEngine | 
MapEventPublisherImpl.nodeEngine  | 
| Constructor and Description | 
|---|
ExpirationManager(PartitionContainer[] partitionContainers,
                 NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
RingbufferMapEventJournalImpl(NodeEngine engine,
                             MapServiceContext mapServiceContext)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected NodeEngine | 
MapNearCacheManager.nodeEngine  | 
| Modifier and Type | Method and Description | 
|---|---|
PartitionAwareOperationFactory | 
PartitionWideEntryWithPredicateOperationFactory.createFactoryOnRunner(NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
MapProxyImpl(String name,
            MapService mapService,
            NodeEngine nodeEngine,
            MapConfig mapConfig)  | 
NearCachedMapProxyImpl(String name,
                      MapService mapService,
                      NodeEngine nodeEngine,
                      MapConfig mapConfig)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected NodeEngine | 
QueryRunner.nodeEngine  | 
protected NodeEngine | 
MapQueryEngineImpl.nodeEngine  | 
protected NodeEngine | 
PartitionScanRunner.nodeEngine  | 
| Modifier and Type | Method and Description | 
|---|---|
NodeEngine | 
DefaultPublisherContext.getNodeEngine()  | 
NodeEngine | 
PublisherContext.getNodeEngine()
Returns underlying  
NodeEngine for this node. | 
| Constructor and Description | 
|---|
DefaultPublisherContext(QueryCacheContext context,
                       NodeEngine nodeEngine,
                       IFunction<String,String> listenerRegistrator)  | 
| Constructor and Description | 
|---|
TransactionalMapProxy(String name,
                     MapService mapService,
                     NodeEngine nodeEngine,
                     Transaction transaction)  | 
| Constructor and Description | 
|---|
MergePolicyProvider(NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
abstract boolean | 
KeyValueSource.open(NodeEngine nodeEngine)
Deprecated.  
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> List<V> | 
MapReduceUtil.executeOperation(Collection<Member> members,
                OperationFactory operationFactory,
                MapReduceService mapReduceService,
                NodeEngine nodeEngine)  | 
static <V> V | 
MapReduceUtil.executeOperation(Operation operation,
                Address address,
                MapReduceService mapReduceService,
                NodeEngine nodeEngine)  | 
void | 
MapReduceService.init(NodeEngine nodeEngine,
    Properties properties)  | 
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(MultiMapConfig config,
                    MultiMapService service,
                    NodeEngine nodeEngine,
                    String name)  | 
MultiMapService(NodeEngine nodeEngine)  | 
ObjectMultiMapProxy(MultiMapConfig config,
                   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)  | 
| Constructor and Description | 
|---|
TransactionalMultiMapProxy(NodeEngine nodeEngine,
                          MultiMapService service,
                          String name,
                          Transaction tx)  | 
| Modifier and Type | Method and Description | 
|---|---|
NodeEngine | 
ReplicatedMapService.getNodeEngine()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReplicatedMapService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
ReplicatedMapEvictionProcessor(ReplicatedRecordStore store,
                              NodeEngine nodeEngine,
                              int partitionId)  | 
ReplicatedMapService(NodeEngine nodeEngine)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected NodeEngine | 
AbstractBaseReplicatedRecordStore.nodeEngine  | 
| Constructor and Description | 
|---|
MergePolicyProvider(NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
RingbufferService.init(NodeEngine nodeEngine,
    Properties properties)  | 
void | 
RingbufferContainer.init(RingbufferConfig config,
    NodeEngine nodeEngine)
Initializes the ring buffer with references to other services, the
 ringbuffer store and the config. 
 | 
| Constructor and Description | 
|---|
RingbufferContainer(ObjectNamespace namespace,
                   RingbufferConfig config,
                   NodeEngine nodeEngine,
                   int partitionId)
Constructs a fully initialized ringbuffer that can be used immediately. 
 | 
RingbufferProxy(NodeEngine nodeEngine,
               RingbufferService service,
               String name,
               RingbufferConfig config)  | 
| Modifier and Type | Method and Description | 
|---|---|
NodeEngine | 
ScheduledExecutorContainer.getNodeEngine()  | 
NodeEngine | 
DistributedScheduledExecutorService.getNodeEngine()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
DistributedScheduledExecutorService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
AbstractScheduledExecutorContainerHolder(NodeEngine nodeEngine)  | 
InvokeOnMembers(NodeEngine nodeEngine,
               String serviceName,
               Supplier<Operation> operationFactory,
               Collection<Member> targets)  | 
ScheduledExecutorMemberBin(NodeEngine nodeEngine)  | 
| 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 service. 
 | 
Operation | 
Operation.setNodeEngine(NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
AbstractDistributedObject(NodeEngine nodeEngine,
                         S service)  | 
TransactionalDistributedObject(NodeEngine nodeEngine,
                              S service,
                              Transaction tx)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
NodeEngineImpl
The NodeEngineImpl is the where the construction of the Hazelcast dependencies take place. 
 | 
| Constructor and Description | 
|---|
AbstractCompletableFuture(NodeEngine nodeEngine,
                         ILogger logger)  | 
BinaryOperationFactory(Operation operation,
                      NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
AbstractContainerCollector(NodeEngine nodeEngine)  | 
AbstractContainerMerger(AbstractContainerCollector<C> collector,
                       NodeEngine nodeEngine)  | 
AbstractMergeRunnable(String serviceName,
                     Collection<Store> mergingStores,
                     AbstractSplitBrainHandlerService<Store> splitBrainHandlerService,
                     NodeEngine nodeEngine)  | 
AbstractNamedContainerCollector(NodeEngine nodeEngine,
                               ConcurrentMap<String,C> containers)  | 
AbstractSplitBrainHandlerService(NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
WaitSet(ILogger logger,
       NodeEngine nodeEngine,
       Map<WaitNotifyKey,WaitSet> waitSetMap,
       Queue<com.hazelcast.spi.impl.operationparker.impl.WaitSetEntry> delayQueue)  | 
| Constructor and Description | 
|---|
PartitionAwareCallableBatchingRunnable(NodeEngine nodeEngine,
                                      PartitionAwareCallableFactory factory)  | 
| Modifier and Type | Method and Description | 
|---|---|
PartitionAwareOperationFactory | 
PartitionAwareOperationFactory.createFactoryOnRunner(NodeEngine nodeEngine)
This method will be called on operation runner node. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
RemoteService | 
RemoteServiceDescriptor.getService(NodeEngine nodeEngine)  | 
| Constructor and Description | 
|---|
SplitBrainMergePolicyProvider(NodeEngine nodeEngine)
Constructs a new provider for  
SplitBrainMergePolicy classes. | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TopicService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
TopicProxy(String name,
          NodeEngine nodeEngine,
          TopicService service)  | 
TopicProxySupport(String name,
                 NodeEngine nodeEngine,
                 TopicService service)  | 
TotalOrderedTopicProxy(String name,
                      NodeEngine nodeEngine,
                      TopicService service)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReliableTopicService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
ReliableTopicProxy(String name,
                  NodeEngine nodeEngine,
                  ReliableTopicService service,
                  ReliableTopicConfig topicConfig)  | 
ReliableTopicService(NodeEngine nodeEngine)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<Future> | 
TransactionLog.commit(NodeEngine nodeEngine)  | 
void | 
TransactionLog.commitAsync(NodeEngine nodeEngine,
           ExecutionCallback callback)  | 
void | 
TransactionManagerServiceImpl.init(NodeEngine nodeEngine,
    Properties properties)  | 
List<Future> | 
TransactionLog.prepare(NodeEngine nodeEngine)  | 
List<Future> | 
TransactionLog.rollback(NodeEngine nodeEngine)  | 
void | 
TransactionLog.rollbackAsync(NodeEngine nodeEngine,
             ExecutionCallback callback)  | 
| Constructor and Description | 
|---|
AllowedDuringPassiveStateTransactionImpl(TransactionManagerServiceImpl transactionManagerService,
                                        NodeEngine nodeEngine,
                                        TransactionOptions options,
                                        String txOwnerUuid)  | 
TransactionImpl(TransactionManagerServiceImpl transactionManagerService,
               NodeEngine nodeEngine,
               TransactionOptions options,
               String txOwnerUuid)  | 
TransactionImpl(TransactionManagerServiceImpl transactionManagerService,
               NodeEngine nodeEngine,
               TransactionOptions options,
               String txOwnerUuid,
               boolean originatedFromClient)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
XAService.init(NodeEngine nodeEngine,
    Properties properties)  | 
| Constructor and Description | 
|---|
XAResourceImpl(NodeEngine nodeEngine,
              XAService service)  | 
XATransaction(NodeEngine nodeEngine,
             List<TransactionLogRecord> logs,
             String txnId,
             SerializableXID xid,
             String txOwnerUuid,
             long timeoutMillis,
             long startTime)  | 
XATransaction(NodeEngine nodeEngine,
             Xid xid,
             String txOwnerUuid,
             int timeout,
             boolean originatedFromClient)  | 
| Constructor and Description | 
|---|
CachedExecutorServiceDelegate(NodeEngine nodeEngine,
                             String name,
                             ExecutorService cachedExecutor,
                             int maxPoolSize,
                             int queueCapacity)  | 
Copyright © 2018 Hazelcast, Inc.. All Rights Reserved.