|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Packages that use NodeEngine | |
|---|---|
| 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.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. With the IdGenerator it is very simple to create cluster wide id's. |
| com.hazelcast.concurrent.lock | This package contains Lock for Hazelcast. The ILock is the distributed version of the 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 ExecutorService and provides all kinds
of additional methods related to distributed systems. |
| com.hazelcast.map.impl | Contains implementation specific classes of com.hazelcast.map package. |
| 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.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.ringbuffer.impl | Contains the Ringbuffer implementation classes. |
| 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.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 |
| Uses of NodeEngine in com.hazelcast.cache.impl |
|---|
| Fields in com.hazelcast.cache.impl declared as NodeEngine | |
|---|---|
protected NodeEngine |
AbstractCacheService.nodeEngine
|
protected NodeEngine |
AbstractCacheRecordStore.nodeEngine
|
| Methods in com.hazelcast.cache.impl that return NodeEngine | |
|---|---|
NodeEngine |
AbstractCacheService.getNodeEngine()
|
NodeEngine |
ICacheService.getNodeEngine()
|
| Methods in com.hazelcast.cache.impl with parameters of type NodeEngine | |
|---|---|
static int |
CacheProxyUtil.getPartitionId(NodeEngine nodeEngine,
Data key)
|
void |
AbstractCacheService.init(NodeEngine nodeEngine,
Properties properties)
|
protected void |
AbstractCacheService.postInit(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.cache.impl with parameters of type NodeEngine | |
|---|---|
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)
|
|
| Uses of NodeEngine in com.hazelcast.client.impl |
|---|
| Methods in com.hazelcast.client.impl with parameters of type NodeEngine | |
|---|---|
void |
ClientEngineImpl.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.client.impl with parameters of type NodeEngine | |
|---|---|
ClientEndpointManagerImpl(ClientEngineImpl clientEngine,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.cluster.impl |
|---|
| Methods in com.hazelcast.cluster.impl with parameters of type NodeEngine | |
|---|---|
void |
ClusterServiceImpl.init(NodeEngine nodeEngine,
Properties properties)
|
| Uses of NodeEngine in com.hazelcast.collection.impl.collection |
|---|
| Fields in com.hazelcast.collection.impl.collection declared as NodeEngine | |
|---|---|
protected NodeEngine |
CollectionService.nodeEngine
|
protected NodeEngine |
CollectionContainer.nodeEngine
|
| Methods in com.hazelcast.collection.impl.collection with parameters of type NodeEngine | |
|---|---|
protected abstract CollectionConfig |
AbstractCollectionProxyImpl.getConfig(NodeEngine nodeEngine)
|
void |
CollectionContainer.init(NodeEngine nodeEngine)
|
void |
CollectionService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.collection.impl.collection with parameters of type NodeEngine | |
|---|---|
AbstractCollectionProxyImpl(String name,
NodeEngine nodeEngine,
S service)
|
|
CollectionContainer(String name,
NodeEngine nodeEngine)
|
|
CollectionService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.list |
|---|
| Methods in com.hazelcast.collection.impl.list with parameters of type NodeEngine | |
|---|---|
protected CollectionConfig |
ListProxyImpl.getConfig(NodeEngine nodeEngine)
|
| Constructors in com.hazelcast.collection.impl.list with parameters of type NodeEngine | |
|---|---|
ListContainer(String name,
NodeEngine nodeEngine)
|
|
ListProxyImpl(String name,
NodeEngine nodeEngine,
ListService service)
|
|
ListService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.queue |
|---|
| Methods in com.hazelcast.collection.impl.queue that return NodeEngine | |
|---|---|
NodeEngine |
QueueService.getNodeEngine()
|
| Methods in com.hazelcast.collection.impl.queue with parameters of type NodeEngine | |
|---|---|
void |
QueueService.init(NodeEngine nodeEngine,
Properties properties)
|
void |
QueueContainer.setConfig(QueueConfig config,
NodeEngine nodeEngine,
QueueService service)
|
| Constructors in com.hazelcast.collection.impl.queue with parameters of type NodeEngine | |
|---|---|
QueueContainer(String name,
QueueConfig config,
NodeEngine nodeEngine,
QueueService service)
|
|
QueueEvictionProcessor(NodeEngine nodeEngine,
QueueService service)
|
|
QueueProxyImpl(String name,
QueueService queueService,
NodeEngine nodeEngine)
|
|
QueueService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.set |
|---|
| Methods in com.hazelcast.collection.impl.set with parameters of type NodeEngine | |
|---|---|
protected CollectionConfig |
SetProxyImpl.getConfig(NodeEngine nodeEngine)
|
| Constructors in com.hazelcast.collection.impl.set with parameters of type NodeEngine | |
|---|---|
SetContainer(String name,
NodeEngine nodeEngine)
|
|
SetProxyImpl(String name,
NodeEngine nodeEngine,
SetService service)
|
|
SetService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.txncollection |
|---|
| Methods in com.hazelcast.collection.impl.txncollection with parameters of type NodeEngine | |
|---|---|
Future |
CollectionTransactionLog.commit(NodeEngine nodeEngine)
|
void |
CollectionTransactionLog.commitAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
Future |
CollectionTransactionLog.prepare(NodeEngine nodeEngine)
|
Future |
CollectionTransactionLog.rollback(NodeEngine nodeEngine)
|
void |
CollectionTransactionLog.rollbackAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
| Constructors in com.hazelcast.collection.impl.txncollection with parameters of type NodeEngine | |
|---|---|
AbstractTransactionalCollectionProxy(String name,
TransactionSupport tx,
NodeEngine nodeEngine,
S service)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.txnlist |
|---|
| Constructors in com.hazelcast.collection.impl.txnlist with parameters of type NodeEngine | |
|---|---|
TransactionalListProxy(String name,
TransactionSupport tx,
NodeEngine nodeEngine,
ListService service)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.txnqueue |
|---|
| Methods in com.hazelcast.collection.impl.txnqueue with parameters of type NodeEngine | |
|---|---|
Future |
QueueTransactionLog.commit(NodeEngine nodeEngine)
|
void |
QueueTransactionLog.commitAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
Future |
QueueTransactionLog.prepare(NodeEngine nodeEngine)
|
Future |
QueueTransactionLog.rollback(NodeEngine nodeEngine)
|
void |
QueueTransactionLog.rollbackAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
| Constructors in com.hazelcast.collection.impl.txnqueue with parameters of type NodeEngine | |
|---|---|
TransactionalQueueProxy(NodeEngine nodeEngine,
QueueService service,
String name,
TransactionSupport tx)
|
|
TransactionalQueueProxySupport(NodeEngine nodeEngine,
QueueService service,
String name,
TransactionSupport tx)
|
|
| Uses of NodeEngine in com.hazelcast.collection.impl.txnset |
|---|
| Constructors in com.hazelcast.collection.impl.txnset with parameters of type NodeEngine | |
|---|---|
TransactionalSetProxy(String name,
TransactionSupport tx,
NodeEngine nodeEngine,
SetService service)
|
|
| Uses of NodeEngine in com.hazelcast.concurrent.atomiclong |
|---|
| Methods in com.hazelcast.concurrent.atomiclong with parameters of type NodeEngine | |
|---|---|
void |
AtomicLongService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.concurrent.atomiclong with parameters of type NodeEngine | |
|---|---|
AtomicLongProxy(String name,
NodeEngine nodeEngine,
AtomicLongService service)
|
|
| Uses of NodeEngine in com.hazelcast.concurrent.atomicreference |
|---|
| Methods in com.hazelcast.concurrent.atomicreference with parameters of type NodeEngine | |
|---|---|
void |
AtomicReferenceService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.concurrent.atomicreference with parameters of type NodeEngine | |
|---|---|
AtomicReferenceProxy(String name,
NodeEngine nodeEngine,
AtomicReferenceService service)
|
|
| Uses of NodeEngine in com.hazelcast.concurrent.countdownlatch |
|---|
| Methods in com.hazelcast.concurrent.countdownlatch with parameters of type NodeEngine | |
|---|---|
void |
CountDownLatchService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.concurrent.countdownlatch with parameters of type NodeEngine | |
|---|---|
CountDownLatchProxy(String name,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.concurrent.idgen |
|---|
| Methods in com.hazelcast.concurrent.idgen with parameters of type NodeEngine | |
|---|---|
void |
IdGeneratorService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.concurrent.idgen with parameters of type NodeEngine | |
|---|---|
IdGeneratorProxy(IAtomicLong blockGenerator,
String name,
NodeEngine nodeEngine,
IdGeneratorService service)
|
|
IdGeneratorService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.concurrent.lock |
|---|
| Methods in com.hazelcast.concurrent.lock with parameters of type NodeEngine | |
|---|---|
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)
|
| Constructors in com.hazelcast.concurrent.lock with parameters of type NodeEngine | |
|---|---|
LockEvictionProcessor(NodeEngine nodeEngine,
ObjectNamespace namespace)
|
|
LockProxy(NodeEngine nodeEngine,
LockServiceImpl lockService,
String name)
|
|
LockServiceImpl(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.concurrent.semaphore |
|---|
| Methods in com.hazelcast.concurrent.semaphore with parameters of type NodeEngine | |
|---|---|
void |
SemaphoreService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.concurrent.semaphore with parameters of type NodeEngine | |
|---|---|
SemaphoreProxy(String name,
SemaphoreService service,
NodeEngine nodeEngine)
|
|
SemaphoreService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.executor.impl |
|---|
| Methods in com.hazelcast.executor.impl with parameters of type NodeEngine | |
|---|---|
void |
DistributedExecutorService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.executor.impl with parameters of type NodeEngine | |
|---|---|
ExecutorServiceProxy(String name,
NodeEngine nodeEngine,
DistributedExecutorService service)
|
|
| Uses of NodeEngine in com.hazelcast.map.impl |
|---|
| Methods in com.hazelcast.map.impl that return NodeEngine | |
|---|---|
NodeEngine |
MapServiceContext.getNodeEngine()
|
| Methods in com.hazelcast.map.impl that return types with arguments of type NodeEngine | |
|---|---|
static ConstructorFunction<NodeEngine,MapService> |
MapServiceConstructor.getDefaultMapServiceConstructor()
Returns a Constructor which will be used to create a MapService object. |
| Methods in com.hazelcast.map.impl with parameters of type NodeEngine | |
|---|---|
void |
MapService.init(NodeEngine nodeEngine,
Properties properties)
|
void |
MapContainer.initWanReplication(NodeEngine nodeEngine)
|
| Constructors in com.hazelcast.map.impl with parameters of type NodeEngine | |
|---|---|
LocalMapStatsProvider(MapServiceContext mapServiceContext,
NodeEngine nodeEngine)
|
|
NearCache(String mapName,
NodeEngine nodeEngine)
|
|
NearCacheProvider(MapServiceContext mapServiceContext,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.map.impl.eviction |
|---|
| Constructors in com.hazelcast.map.impl.eviction with parameters of type NodeEngine | |
|---|---|
ExpirationManager(MapServiceContext mapServiceContext,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.map.impl.proxy |
|---|
| Constructors in com.hazelcast.map.impl.proxy with parameters of type NodeEngine | |
|---|---|
MapProxyImpl(String name,
MapService mapService,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.map.impl.tx |
|---|
| Methods in com.hazelcast.map.impl.tx with parameters of type NodeEngine | |
|---|---|
Future |
MapTransactionLog.commit(NodeEngine nodeEngine)
|
void |
MapTransactionLog.commitAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
Future |
MapTransactionLog.prepare(NodeEngine nodeEngine)
|
Future |
MapTransactionLog.rollback(NodeEngine nodeEngine)
|
void |
MapTransactionLog.rollbackAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
| Constructors in com.hazelcast.map.impl.tx with parameters of type NodeEngine | |
|---|---|
TransactionalMapProxy(String name,
MapService mapService,
NodeEngine nodeEngine,
TransactionSupport transaction)
|
|
TransactionalMapProxySupport(String name,
MapService mapService,
NodeEngine nodeEngine,
TransactionSupport transaction)
|
|
| Uses of NodeEngine in com.hazelcast.map.merge |
|---|
| Constructors in com.hazelcast.map.merge with parameters of type NodeEngine | |
|---|---|
MergePolicyProvider(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.mapreduce |
|---|
| Methods in com.hazelcast.mapreduce with parameters of type NodeEngine | |
|---|---|
abstract boolean |
KeyValueSource.open(NodeEngine nodeEngine)
This method is called before accessing the key-value pairs of this KeyValueSource. |
| Uses of NodeEngine in com.hazelcast.mapreduce.impl |
|---|
| Fields in com.hazelcast.mapreduce.impl declared as NodeEngine | |
|---|---|
protected NodeEngine |
AbstractJobTracker.nodeEngine
|
| Methods in com.hazelcast.mapreduce.impl that return NodeEngine | |
|---|---|
NodeEngine |
MapReduceService.getNodeEngine()
|
| Methods in com.hazelcast.mapreduce.impl with parameters of type NodeEngine | ||
|---|---|---|
static
|
MapReduceUtil.executeOperation(Operation operation,
Address address,
MapReduceService mapReduceService,
NodeEngine nodeEngine)
|
|
static
|
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)
|
|
| Constructors in com.hazelcast.mapreduce.impl with parameters of type NodeEngine | |
|---|---|
MapReduceService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.mapreduce.impl.task |
|---|
| Methods in com.hazelcast.mapreduce.impl.task that return NodeEngine | |
|---|---|
NodeEngine |
JobTaskConfiguration.getNodeEngine()
|
| Constructors in com.hazelcast.mapreduce.impl.task with parameters of type NodeEngine | |
|---|---|
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)
|
|
| Uses of NodeEngine in com.hazelcast.multimap.impl |
|---|
| Methods in com.hazelcast.multimap.impl that return NodeEngine | |
|---|---|
NodeEngine |
MultiMapService.getNodeEngine()
|
| Methods in com.hazelcast.multimap.impl with parameters of type NodeEngine | |
|---|---|
void |
MultiMapService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.multimap.impl with parameters of type NodeEngine | |
|---|---|
MultiMapEventsPublisher(NodeEngine nodeEngine)
|
|
MultiMapProxySupport(MultiMapService service,
NodeEngine nodeEngine,
String name)
|
|
MultiMapService(NodeEngine nodeEngine)
|
|
ObjectMultiMapProxy(MultiMapService service,
NodeEngine nodeEngine,
String name)
|
|
| Uses of NodeEngine in com.hazelcast.multimap.impl.operations |
|---|
| Methods in com.hazelcast.multimap.impl.operations with parameters of type NodeEngine | ||
|---|---|---|
Collection |
MultiMapResponse.getObjectCollection(NodeEngine nodeEngine)
|
|
|
EntrySetResponse.getObjectEntrySet(NodeEngine nodeEngine)
|
|
Collection<MultiMapRecord> |
MultiMapResponse.getRecordCollection(NodeEngine nodeEngine)
|
|
| Constructors in com.hazelcast.multimap.impl.operations with parameters of type NodeEngine | |
|---|---|
EntrySetResponse(Map<Data,Collection<MultiMapRecord>> map,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.multimap.impl.txn |
|---|
| Methods in com.hazelcast.multimap.impl.txn with parameters of type NodeEngine | |
|---|---|
Future |
MultiMapTransactionLog.commit(NodeEngine nodeEngine)
|
void |
MultiMapTransactionLog.commitAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
Future |
MultiMapTransactionLog.prepare(NodeEngine nodeEngine)
|
Future |
MultiMapTransactionLog.rollback(NodeEngine nodeEngine)
|
void |
MultiMapTransactionLog.rollbackAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
| Constructors in com.hazelcast.multimap.impl.txn with parameters of type NodeEngine | |
|---|---|
TransactionalMultiMapProxy(NodeEngine nodeEngine,
MultiMapService service,
String name,
TransactionSupport tx)
|
|
TransactionalMultiMapProxySupport(NodeEngine nodeEngine,
MultiMapService service,
String name,
TransactionSupport tx)
|
|
| Uses of NodeEngine in com.hazelcast.partition.impl |
|---|
| Methods in com.hazelcast.partition.impl with parameters of type NodeEngine | |
|---|---|
void |
InternalPartitionServiceImpl.init(NodeEngine nodeEngine,
Properties properties)
|
| Uses of NodeEngine in com.hazelcast.replicatedmap.impl |
|---|
| Methods in com.hazelcast.replicatedmap.impl with parameters of type NodeEngine | |
|---|---|
void |
ReplicatedMapService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.replicatedmap.impl with parameters of type NodeEngine | |
|---|---|
ReplicatedMapEvictionProcessor(NodeEngine nodeEngine,
ReplicatedMapService replicatedMapService,
String mapName)
|
|
ReplicatedMapService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.replicatedmap.impl.record |
|---|
| Constructors in com.hazelcast.replicatedmap.impl.record with parameters of type NodeEngine | |
|---|---|
AbstractReplicatedRecordStore(String name,
NodeEngine nodeEngine,
ReplicatedMapService replicatedMapService)
|
|
DataReplicatedRecordStore(String name,
NodeEngine nodeEngine,
ReplicatedMapService replicatedMapService)
|
|
ObjectReplicatedRecordStorage(String name,
NodeEngine nodeEngine,
ReplicatedMapService replicatedMapService)
|
|
| Uses of NodeEngine in com.hazelcast.ringbuffer.impl |
|---|
| Methods in com.hazelcast.ringbuffer.impl with parameters of type NodeEngine | |
|---|---|
void |
RingbufferContainer.init(NodeEngine nodeEngine)
|
void |
RingbufferService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.ringbuffer.impl with parameters of type NodeEngine | |
|---|---|
RingbufferProxy(NodeEngine nodeEngine,
RingbufferService service,
String name,
RingbufferConfig config)
|
|
| Uses of NodeEngine in com.hazelcast.spi |
|---|
| Methods in com.hazelcast.spi that return NodeEngine | |
|---|---|
NodeEngine |
AbstractDistributedObject.getNodeEngine()
Gets the node engine. |
NodeEngine |
Operation.getNodeEngine()
|
| Methods in com.hazelcast.spi with parameters of type NodeEngine | |
|---|---|
void |
ManagedService.init(NodeEngine nodeEngine,
Properties properties)
Initializes this ManagedService |
Operation |
Operation.setNodeEngine(NodeEngine nodeEngine)
|
| Constructors in com.hazelcast.spi with parameters of type NodeEngine | |
|---|---|
AbstractDistributedObject(NodeEngine nodeEngine,
S service)
|
|
| Uses of NodeEngine in com.hazelcast.spi.impl |
|---|
| Classes in com.hazelcast.spi.impl that implement NodeEngine | |
|---|---|
class |
NodeEngineImpl
The NodeEngineImpl is the where the construction of the Hazelcast dependencies take place. |
| Fields in com.hazelcast.spi.impl declared as NodeEngine | |
|---|---|
protected NodeEngine |
AbstractCompletableFuture.nodeEngine
|
| Methods in com.hazelcast.spi.impl with parameters of type NodeEngine | |
|---|---|
static ResponseHandler |
ResponseHandlerFactory.createRemoteResponseHandler(NodeEngine nodeEngine,
Operation operation)
|
static void |
ResponseHandlerFactory.setRemoteResponseHandler(NodeEngine nodeEngine,
Operation operation)
|
| Constructors in com.hazelcast.spi.impl with parameters of type NodeEngine | |
|---|---|
AbstractCompletableFuture(NodeEngine nodeEngine,
ILogger logger)
|
|
BinaryOperationFactory(Operation operation,
NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.topic.impl |
|---|
| Methods in com.hazelcast.topic.impl with parameters of type NodeEngine | |
|---|---|
void |
TopicService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.topic.impl with parameters of type NodeEngine | |
|---|---|
TopicProxy(String name,
NodeEngine nodeEngine,
TopicService service)
|
|
TopicProxySupport(String name,
NodeEngine nodeEngine,
TopicService service)
|
|
TotalOrderedTopicProxy(String name,
NodeEngine nodeEngine,
TopicService service)
|
|
| Uses of NodeEngine in com.hazelcast.topic.impl.reliable |
|---|
| Constructors in com.hazelcast.topic.impl.reliable with parameters of type NodeEngine | |
|---|---|
ReliableTopicProxy(String name,
NodeEngine nodeEngine,
ReliableTopicService service,
ReliableTopicConfig topicConfig)
|
|
ReliableTopicService(NodeEngine nodeEngine)
|
|
| Uses of NodeEngine in com.hazelcast.transaction.impl |
|---|
| Methods in com.hazelcast.transaction.impl with parameters of type NodeEngine | |
|---|---|
Future |
TransactionLog.commit(NodeEngine nodeEngine)
|
void |
TransactionLog.commitAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
void |
TransactionManagerServiceImpl.init(NodeEngine nodeEngine,
Properties properties)
|
Future |
TransactionLog.prepare(NodeEngine nodeEngine)
|
Future |
TransactionLog.rollback(NodeEngine nodeEngine)
|
void |
TransactionLog.rollbackAsync(NodeEngine nodeEngine,
ExecutionCallback callback)
|
| Constructors in com.hazelcast.transaction.impl with parameters of type NodeEngine | |
|---|---|
TransactionImpl(TransactionManagerServiceImpl transactionManagerService,
NodeEngine nodeEngine,
TransactionOptions options,
String txOwnerUuid)
|
|
| Uses of NodeEngine in com.hazelcast.transaction.impl.xa |
|---|
| Methods in com.hazelcast.transaction.impl.xa with parameters of type NodeEngine | |
|---|---|
void |
XAService.init(NodeEngine nodeEngine,
Properties properties)
|
| Constructors in com.hazelcast.transaction.impl.xa with parameters of type NodeEngine | |
|---|---|
XAResourceImpl(NodeEngine nodeEngine,
XAService service)
|
|
| Uses of NodeEngine in com.hazelcast.util.executor |
|---|
| Constructors in com.hazelcast.util.executor with parameters of type NodeEngine | |
|---|---|
CachedExecutorServiceDelegate(NodeEngine nodeEngine,
String name,
ExecutorService cachedExecutor,
int maxPoolSize,
int queueCapacity)
|
|
|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||