Package | Description |
---|---|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.event |
Event classes to define listenters for JCache other than EntryListener
|
com.hazelcast.cache.impl.eviction | |
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.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cardinality.impl | |
com.hazelcast.cardinality.impl.operations |
This package contains the operations on the
CardinalityEstimator . |
com.hazelcast.client.cache.impl |
Hazelcast JSR-107 aka JCache implementation client side
|
com.hazelcast.client.cache.impl.nearcache.invalidation | |
com.hazelcast.client.impl |
Implementation classes of the com.hazelcast.client interfaces
|
com.hazelcast.client.impl.operations |
Contains client operations
|
com.hazelcast.client.impl.protocol |
Client protocol related private implementation classes
|
com.hazelcast.client.impl.protocol.task |
Client tasks associated with requests.
|
com.hazelcast.client.impl.protocol.task.atomiclong |
Client protocol tasks implementations for AtomicLong
|
com.hazelcast.client.impl.protocol.task.atomicreference |
Client protocol tasks implementations for AtomicReference
|
com.hazelcast.client.impl.protocol.task.cache |
Client protocol tasks implementations for JCache
|
com.hazelcast.client.impl.protocol.task.cardinality | |
com.hazelcast.client.impl.protocol.task.condition |
Client protocol tasks implementations for Condition
|
com.hazelcast.client.impl.protocol.task.countdownlatch |
Client protocol tasks implementations for CountDownLatch
|
com.hazelcast.client.impl.protocol.task.crdt.pncounter | |
com.hazelcast.client.impl.protocol.task.executorservice |
Client protocol tasks implementations for ExecutorService
|
com.hazelcast.client.impl.protocol.task.executorservice.durable | |
com.hazelcast.client.impl.protocol.task.list |
Client protocol tasks implementations for List
|
com.hazelcast.client.impl.protocol.task.lock |
Client protocol tasks implementations for ILock
|
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
com.hazelcast.client.impl.protocol.task.multimap |
Client protocol tasks implementations for multi map
|
com.hazelcast.client.impl.protocol.task.queue |
Client protocol tasks implementations for Queue
|
com.hazelcast.client.impl.protocol.task.replicatedmap |
Client protocol tasks implementations for ReplicatedMap
|
com.hazelcast.client.impl.protocol.task.ringbuffer |
Client protocol tasks implementations for Ringbuffer
|
com.hazelcast.client.impl.protocol.task.scheduledexecutor | |
com.hazelcast.client.impl.protocol.task.semaphore |
Client protocol tasks implementations for Semaphore
|
com.hazelcast.client.impl.protocol.task.set |
Client protocol tasks implementations for set
|
com.hazelcast.client.impl.protocol.task.topic |
Client protocol tasks implementations for Topic
|
com.hazelcast.client.impl.protocol.task.transaction |
Client protocol tasks implementations for Transaction related
|
com.hazelcast.client.impl.querycache.subscriber |
Contains Hazelcast Enterprise version client-side query cache
subscriber implementation classes.
|
com.hazelcast.client.map.impl.nearcache.invalidation | |
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 the Hazelcast client Service Provider Interface.
|
com.hazelcast.client.spi.impl |
Provides util classes for the Hazelcast client SPI.
|
com.hazelcast.client.util |
This package contains some utility classes and the base implementations of the
loadbalancer implementations
|
com.hazelcast.collection.impl | |
com.hazelcast.collection.impl.collection | |
com.hazelcast.collection.impl.collection.operations | |
com.hazelcast.collection.impl.list |
This package contains IList functionality for Hazelcast.
|
com.hazelcast.collection.impl.list.operations | |
com.hazelcast.collection.impl.queue | |
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.set |
This package contains ISet functionality for Hazelcast.
|
com.hazelcast.collection.impl.set.operations | |
com.hazelcast.collection.impl.txncollection | |
com.hazelcast.collection.impl.txncollection.operations | |
com.hazelcast.collection.impl.txnlist | |
com.hazelcast.collection.impl.txnqueue | |
com.hazelcast.collection.impl.txnqueue.operations | |
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.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.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
com.hazelcast.concurrent.countdownlatch |
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch . |
com.hazelcast.concurrent.countdownlatch.operations |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.idgen |
This package contains IdGenerator functionality for Hazelcast.
|
com.hazelcast.concurrent.lock | |
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.concurrent.semaphore |
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the Semaphore . |
com.hazelcast.concurrent.semaphore.operations |
This package contains the operations on the ISemaphore.
|
com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
com.hazelcast.cp.internal |
Contains implementation of the CP subsystem
|
com.hazelcast.cp.internal.datastructures.atomiclong |
Contains service classes for the Raft-based
IAtomicLong implementation |
com.hazelcast.cp.internal.datastructures.atomiclong.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.atomicref |
Contains service classes for the Raft-based
IAtomicReference implementation |
com.hazelcast.cp.internal.datastructures.atomicref.proxy |
Contains
IAtomicReference functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.countdownlatch |
Contains service classes for the Raft-based
ICountDownLatch implementation |
com.hazelcast.cp.internal.datastructures.countdownlatch.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.lock |
Contains service classes for the Raft-based
ILock
and FencedLock implementation |
com.hazelcast.cp.internal.datastructures.lock.proxy |
Contains
ILock functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.semaphore |
Contains service classes for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.datastructures.semaphore.proxy |
Contains
ISemaphore functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.spi |
Contains the abstractions that is used for managing proxies
for the Raft-based data structure implementations
|
com.hazelcast.cp.internal.datastructures.spi.blocking |
Contains the interfaces and abstractions that are implemented / extended
by blocking Raft services, such as Lock, Semaphore, and CountDownLatch
|
com.hazelcast.cp.internal.operation |
Contains operations for the Raft Invocation SPI
|
com.hazelcast.cp.internal.operation.integration |
Contains Hazelcast operations that carry out Raft RPCs
|
com.hazelcast.cp.internal.raftop.metadata |
Contains operations that are used in the Metadata CP group
|
com.hazelcast.cp.internal.session |
Contains service classes
for the Raft-based
ISemaphore implementation |
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.crdt.pncounter.operations |
Contains the operations for the
PNCounter member-side
implementation. |
com.hazelcast.durableexecutor.impl |
Contains the
DurableExecutorService implementation classes. |
com.hazelcast.durableexecutor.impl.operations |
This package contains operations for the DurableExecutorService.
|
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.executor.impl.operations |
This package contains operations for the IExecutorService.
|
com.hazelcast.flakeidgen.impl | |
com.hazelcast.internal.cluster |
Contains the internals for cluster management like discovery, joining etc.
|
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.internal.diagnostics |
Contains functionality what is happening in a HazelcastInstance.
|
com.hazelcast.internal.dynamicconfig |
Classes related to Dynamic Configuration.
|
com.hazelcast.internal.eviction |
Eviction policy implementations.
|
com.hazelcast.internal.jmx |
Contains Hazelcast management bean classes.
|
com.hazelcast.internal.journal |
This package contains supporting classes for data structure specific event journals.
|
com.hazelcast.internal.management |
Contains classes to provide data/operation interface for Management Center.
|
com.hazelcast.internal.management.dto |
These contain the DTO object to exchange information with the management center.
|
com.hazelcast.internal.management.operation |
Contains operations that are called from Management Center.
|
com.hazelcast.internal.nearcache |
Near Cache support.
|
com.hazelcast.internal.nearcache.impl |
Near Cache implementations.
|
com.hazelcast.internal.nearcache.impl.invalidation |
Invalidations for Near Cache.
|
com.hazelcast.internal.nearcache.impl.store |
Near Cache store implementations.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.internal.partition.operation |
Contains the operations for partition package.
|
com.hazelcast.internal.usercodedeployment |
Module related to User Code Deployment
|
com.hazelcast.internal.usercodedeployment.impl | |
com.hazelcast.internal.usercodedeployment.impl.operation | |
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.nearcache.invalidation | |
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 |
Contains query cache internal implementation classes.
|
com.hazelcast.map.impl.querycache.publisher |
This package contains classes which are used for
QueryCache
event publishing side. |
com.hazelcast.map.impl.querycache.subscriber |
This package contains classes which are used for
QueryCache
event subscription side. |
com.hazelcast.map.impl.querycache.subscriber.operation |
This package contains Enterprise specific operations for
QueryCache . |
com.hazelcast.map.impl.recordstore | |
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.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
com.hazelcast.mapreduce.impl.task |
This package contains the base implementation for a standard map reduce job.
|
com.hazelcast.multimap.impl |
Contains classes for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.txn |
This package contains the Transaction behavior for the Multimap.
|
com.hazelcast.nio |
This package contains classes related to New IO
|
com.hazelcast.quorum.impl |
Contains cluster quorum implementation classes.
|
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.operation |
This package contains replicated map operations which are executed on remote nodes
|
com.hazelcast.replicatedmap.impl.record |
This package contains the implementation of the backing data storage for the replicated map implementation
|
com.hazelcast.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.scheduledexecutor.impl | |
com.hazelcast.scheduledexecutor.impl.operations | |
com.hazelcast.security |
Provides interfaces/classes for Hazelcast security implementation.
|
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.eventservice |
Contains the code for the
InternalEventService . |
com.hazelcast.spi.impl.eventservice.impl |
Contains the code for the
InternalEventService implementation. |
com.hazelcast.spi.impl.eventservice.impl.operations |
Contains the operations for the
EventServiceImpl . |
com.hazelcast.spi.impl.executionservice |
Contains the API for the
InternalExecutionService . |
com.hazelcast.spi.impl.executionservice.impl |
Contains the implementation of the
InternalExecutionService . |
com.hazelcast.spi.impl.merge |
This package contains split-brain related classes.
|
com.hazelcast.spi.impl.operationexecutor |
Contains the
OperationRunner code. |
com.hazelcast.spi.impl.operationexecutor.impl |
Contains the
OperationExecutorImpl code. |
com.hazelcast.spi.impl.operationparker |
Contains the internal API code for the
OperationParker . |
com.hazelcast.spi.impl.operationparker.impl |
Contains the implementation code for the
OperationParker . |
com.hazelcast.spi.impl.operationservice |
Contains the
InternalOperationService API. |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.spi.impl.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.spi.impl.operationutil |
Contains utiliy classes related to
Operation |
com.hazelcast.spi.impl.proxyservice |
Contains the API for the
InternalProxyService . |
com.hazelcast.spi.impl.proxyservice.impl |
Contains the implementation of the
InternalProxyService . |
com.hazelcast.spi.impl.proxyservice.impl.operations |
Contains the operations for the
ProxyServiceImpl . |
com.hazelcast.spi.impl.servicemanager |
Contains the API for the
ServiceManager . |
com.hazelcast.spi.impl.servicemanager.impl |
Contains the
ServiceManager implementation. |
com.hazelcast.spi.merge |
This package contains interfaces and classes of the split-brain merging SPI.
|
com.hazelcast.spi.partition |
Contains the SPI for partition logic for Hazelcast.
|
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.operations | |
com.hazelcast.transaction.impl.xa |
Provides implementation for Hazelcast XA transaction support.
|
com.hazelcast.transaction.impl.xa.operations | |
com.hazelcast.util.executor |
This package contains classes related to Util.Executor
|
com.hazelcast.util.scheduler |
This package contains scheduler classes for Util
|
com.hazelcast.wan |
This package contains the WAN replication API
|
com.hazelcast.wan.impl |
This package contains the opensource implementation of WAN replication
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
EventRegistration
The result of a Event Registration.
|
FragmentedMigrationAwareService
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows
migration/replication of partition replicas in smaller fragments. |
ListenerWrapperEventFilter
Contract point for
EventFilter instances these wrap listeners. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
NotifiableEventListener
Contract point for event listeners to be notified by
EventService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareService
An interface that can be implemented by SPI services to get notified of when a partition-related event occurs; for example,
if a
MapService notifies its map listeners when partition is lost for a map. |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
PreJoinAwareService
Services which need to perform operations on a joining member just before the member is set as joined must implement
this interface.
|
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
AbstractLocalOperation
Abstract class for local operations, which should not be serializable.
|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
EventPublishingService
A service for publishing events.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
ExecutionService
A Service responsible for providing access to 'system' executors and customer executors.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PreJoinAwareService
Services which need to perform operations on a joining member just before the member is set as joined must implement
this interface.
|
ProxyService
A
CoreService responsible for managing the DistributedObject proxies. |
Class and Description |
---|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Class and Description |
---|
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventPublishingService
A service for publishing events.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
AbstractWaitNotifyKey
Abstract implementation of the WaitNotifyKey.
|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventPublishingService
A service for publishing events.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationService
The OperationService is responsible for executing operations.
|
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
TransactionalDistributedObject
To centralize de-serialization for transactional proxies
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
TransactionalDistributedObject
To centralize de-serialization for transactional proxies
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
TransactionalDistributedObject
To centralize de-serialization for transactional proxies
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
TransactionalDistributedObject
To centralize de-serialization for transactional proxies
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
AbstractWaitNotifyKey
Abstract implementation of the WaitNotifyKey.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ClientAwareService
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
|
FragmentedMigrationAwareService
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows
migration/replication of partition replicas in smaller fragments. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SharedService
Deprecated.
since 3.7. A service can be retrieved using
NodeEngine.getService(String) |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
AbstractWaitNotifyKey
Abstract implementation of the WaitNotifyKey.
|
ClientAwareService
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
MemberAddressProvider
IMPORTANT
This interface is not intended to provide addresses of other cluster members with
which the hazelcast instance will form a cluster.
|
Class and Description |
---|
GracefulShutdownAwareService
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving
their internal data to another node or releasing their allocated resources gracefully.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PreJoinAwareService
Services which need to perform operations on a joining member just before the member is set as joined must implement
this interface.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
Class and Description |
---|
LiveOperations
InvocationMonitor passes instances of this type to each LiveOperationsTracker
so it can contribute the call IDs of invocations it is responsible for. |
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
CallStatus
The result of an
Operation.call() . |
Operation
An operation could be compared to a
Runnable . |
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
GracefulShutdownAwareService
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving
their internal data to another node or releasing their allocated resources gracefully.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
GracefulShutdownAwareService
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving
their internal data to another node or releasing their allocated resources gracefully.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
Class and Description |
---|
AbstractWaitNotifyKey
Abstract implementation of the WaitNotifyKey.
|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Class and Description |
---|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
EventPublishingService
A service for publishing events.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
Class and Description |
---|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
Operation
An operation could be compared to a
Runnable . |
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PreJoinAwareService
Services which need to perform operations on a joining member just before the member is set as joined must implement
this interface.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
EventService
Component responsible for handling events like topic events or map.listener events.
|
ProxyService
A
CoreService responsible for managing the DistributedObject proxies. |
Class and Description |
---|
BlockingOperation
An interface that can be implemented by an operation that can block.
|
DistributedObjectNamespace
Default
ObjectNamespace implementation for DistributedObject . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
EventService
Component responsible for handling events like topic events or map.listener events.
|
ProxyService
A
CoreService responsible for managing the DistributedObject proxies. |
Class and Description |
---|
AbstractLocalOperation
Abstract class for local operations, which should not be serializable.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
Class and Description |
---|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
Class and Description |
---|
EventRegistration
The result of a Event Registration.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
Class and Description |
---|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
GracefulShutdownAwareService
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving
their internal data to another node or releasing their allocated resources gracefully.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
Operation
An operation could be compared to a
Runnable . |
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
EventPublishingService
A service for publishing events.
|
GracefulShutdownAwareService
An interface that can be implemented by SPI services to participate in graceful shutdown process, such as moving
their internal data to another node or releasing their allocated resources gracefully.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareService
An interface that can be implemented by SPI services to get notified of when a partition-related event occurs; for example,
if a
MapService notifies its map listeners when partition is lost for a map. |
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
CallStatus
The result of an
Operation.call() . |
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
PartitionMigrationEvent
An
EventObject for a partition migration. |
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
UrgentSystemOperation
An Marker interface that signals that an operation is an urgent System Operation.
|
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationResponseHandler
A handler for the
OperationService when it has calculated a response. |
Class and Description |
---|
ClientAwareService
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
EventRegistration
The result of a Event Registration.
|
ExecutionService
A Service responsible for providing access to 'system' executors and customer executors.
|
FragmentedMigrationAwareService
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows
migration/replication of partition replicas in smaller fragments. |
LockInterceptorService
Interface to be implemented by services that need to intercept lock operation
for distributed objects it manages.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
NotifiableEventListener
Contract point for event listeners to be notified by
EventService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
OperationService
The OperationService is responsible for executing operations.
|
PartitionAwareService
An interface that can be implemented by SPI services to get notified of when a partition-related event occurs; for example,
if a
MapService notifies its map listeners when partition is lost for a map. |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
PostJoinAwareService
Marker interface for services that want to return operations to be executed on the cluster
members after a join has been finalized.
|
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
ReplicationSupportingService
An interface that can be implemented by SPI services to give them the
ability to listen to WAN replication events.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
EventRegistration
The result of a Event Registration.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
OperationService
The OperationService is responsible for executing operations.
|
Class and Description |
---|
AbstractLocalOperation
Abstract class for local operations, which should not be serializable.
|
AbstractWaitNotifyKey
Abstract implementation of the WaitNotifyKey.
|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
CallStatus
The result of an
Operation.call() . |
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Notifier
A component used in wait/notify systems like Condition.
|
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationService
The OperationService is responsible for executing operations.
|
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
Class and Description |
---|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
Class and Description |
---|
EventService
Component responsible for handling events like topic events or map.listener events.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
OperationService
The OperationService is responsible for executing operations.
|
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
TransactionalDistributedObject
To centralize de-serialization for transactional proxies
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
FragmentedMigrationAwareService
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows
migration/replication of partition replicas in smaller fragments. |
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
LockInterceptorService
Interface to be implemented by services that need to intercept lock operation
for distributed objects it manages.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
TransactionalService
An interface that can be implemented by SPI services that want to deal with transactions.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
TransactionalDistributedObject
To centralize de-serialization for transactional proxies
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
EventService
Component responsible for handling events like topic events or map.listener events.
|
Class and Description |
---|
EventPublishingService
A service for publishing events.
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventFilter
A predicate that can filter out events.
|
EventPublishingService
A service for publishing events.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Class and Description |
---|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
FragmentedMigrationAwareService
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows
migration/replication of partition replicas in smaller fragments. |
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Notifier
A component used in wait/notify systems like Condition.
|
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
ServiceNamespaceAware
An object which is aware of
ServiceNamespace which object itself belongs to. |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
AbstractWaitNotifyKey
Abstract implementation of the WaitNotifyKey.
|
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeAware
A 'capability' that can be implemented by object to get the Node injected.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
QuorumAwareService
Quorum service can ask for quorum information to the
QuorumAwareService
to decide whether operation participates into a quorum or not. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
BlockingOperation
An interface that can be implemented by an operation that can block.
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
Notifier
A component used in wait/notify systems like Condition.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
ReadonlyOperation
Read-only operations are allowed to run during migration and passive state.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
NodeAware
A 'capability' that can be implemented by object to get the Node injected.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
CallStatus
The result of an
Operation.call() . |
CoreService
Marker interface for core Hazelcast services.
|
DefaultObjectNamespace
Deprecated.
please use
DistributedObjectNamespace |
EventFilter
A predicate that can filter out events.
|
EventRegistration
The result of a Event Registration.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
ExecutionService
A Service responsible for providing access to 'system' executors and customer executors.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
LiveOperations
InvocationMonitor passes instances of this type to each LiveOperationsTracker
so it can contribute the call IDs of invocations it is responsible for. |
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
ObjectNamespace
An ObjectNamespace that makes identification of object within a service possible.
|
Operation
An operation could be compared to a
Runnable . |
OperationControl
Content of an Operation Control packet:
a list of operations the remote member started on this member which are still running;
a list of operations this member wants to cancel on the remote member.
Operations are identified by their call ID.
|
OperationFactory
A Factory for creating
Operation instances. |
OperationResponseHandler
A handler for the
OperationService when it has calculated a response. |
OperationService
The OperationService is responsible for executing operations.
|
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
ProxyService
A
CoreService responsible for managing the DistributedObject proxies. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SharedService
Deprecated.
since 3.7. A service can be retrieved using
NodeEngine.getService(String) |
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
FragmentedMigrationAwareService
FragmentedMigrationAwareService is an extension to the MigrationAwareService which allows
migration/replication of partition replicas in smaller fragments. |
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeAware
A 'capability' that can be implemented by object to get the Node injected.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
OperationResponseHandler
A handler for the
OperationService when it has calculated a response. |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
ServiceNamespace
ServiceNamespace is a namespace to group objects, structures, fragments within a service. |
SharedService
Deprecated.
since 3.7. A service can be retrieved using
NodeEngine.getService(String) |
Class and Description |
---|
EventRegistration
The result of a Event Registration.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
PostJoinAwareService
Marker interface for services that want to return operations to be executed on the cluster
members after a join has been finalized.
|
PreJoinAwareService
Services which need to perform operations on a joining member just before the member is set as joined must implement
this interface.
|
Class and Description |
---|
EventFilter
A predicate that can filter out events.
|
EventRegistration
The result of a Event Registration.
|
EventService
Component responsible for handling events like topic events or map.listener events.
|
Operation
An operation could be compared to a
Runnable . |
PostJoinAwareService
Marker interface for services that want to return operations to be executed on the cluster
members after a join has been finalized.
|
PreJoinAwareService
Services which need to perform operations on a joining member just before the member is set as joined must implement
this interface.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
ExecutionService
A Service responsible for providing access to 'system' executors and customer executors.
|
Class and Description |
---|
ExecutionService
A Service responsible for providing access to 'system' executors and customer executors.
|
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
SplitBrainHandlerService
An interface that can be implemented by SPI services that want to be able to resolve a split-brain.
|
Class and Description |
---|
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
LiveOperations
InvocationMonitor passes instances of this type to each LiveOperationsTracker
so it can contribute the call IDs of invocations it is responsible for. |
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
BlockingOperation
An interface that can be implemented by an operation that can block.
|
Notifier
A component used in wait/notify systems like Condition.
|
Class and Description |
---|
BlockingOperation
An interface that can be implemented by an operation that can block.
|
LiveOperations
InvocationMonitor passes instances of this type to each LiveOperationsTracker
so it can contribute the call IDs of invocations it is responsible for. |
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Notifier
A component used in wait/notify systems like Condition.
|
WaitNotifyKey
A key for a wait notify object e.g.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
OperationService
The OperationService is responsible for executing operations.
|
Class and Description |
---|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
InvocationBuilder
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
|
LiveOperations
InvocationMonitor passes instances of this type to each LiveOperationsTracker
so it can contribute the call IDs of invocations it is responsible for. |
LiveOperationsTracker
Can be implemented by a Service to track live operations.
|
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
OperationResponseHandler
A handler for the
OperationService when it has calculated a response. |
OperationService
The OperationService is responsible for executing operations.
|
Class and Description |
---|
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
CallStatus
The result of an
Operation.call() . |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
OperationFactory
A Factory for creating
Operation instances. |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
ProxyService
A
CoreService responsible for managing the DistributedObject proxies. |
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
EventPublishingService
A service for publishing events.
|
Operation
An operation could be compared to a
Runnable . |
PostJoinAwareService
Marker interface for services that want to return operations to be executed on the cluster
members after a join has been finalized.
|
ProxyService
A
CoreService responsible for managing the DistributedObject proxies. |
Class and Description |
---|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
SharedService
Deprecated.
since 3.7. A service can be retrieved using
NodeEngine.getService(String) |
Class and Description |
---|
SharedService
Deprecated.
since 3.7. A service can be retrieved using
NodeEngine.getService(String) |
Class and Description |
---|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
EventPublishingService
A service for publishing events.
|
InitializingObject
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NamedOperation
Indicates that
Operation carries the distributed data structure name that is going to work on. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Class and Description |
---|
ClientAwareService
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MemberAttributeServiceEvent
This service event is fired to inform services about a change in a member's attributes collection
|
MembershipAwareService
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
|
MembershipServiceEvent
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
|
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
ExceptionAction
The possible actions that can be taken when a certain exception is thrown.
|
Operation
An operation could be compared to a
Runnable . |
Class and Description |
---|
AbstractDistributedObject
Abstract DistributedObject implementation.
|
ManagedService
An interface that can be implemented by an SPI Service to receive lifecycle calls:
initialization
shutdown
reset
|
MigrationAwareService
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
MapService starts moving its data around because partitions are moving
to a different machine. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Operation
An operation could be compared to a
Runnable . |
PartitionMigrationEvent
An
EventObject for a partition migration. |
PartitionReplicationEvent
An event send to
MigrationAwareService when partition changes happen. |
RemoteService
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
|
Class and Description |
---|
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
BackupOperation is created to replicate the backup. |
BackupOperation
When an
BackupAwareOperation makes a change, the backups need to be replicated to other
members (depending on the configuration and if change really happened). |
Operation
An operation could be compared to a
Runnable . |
PartitionAwareOperation
An interface that can be implemented by an operation to indicate that it should
be invoked on a particular partition.
|
Class and Description |
---|
InternalCompletableFuture
A
ICompletableFuture with more functionality like getting
the result without needing to deal with checked exceptions. |
NodeEngine
The NodeEngine is the 'umbrella' of services/service-method that gets injected into a
ManagedService . |
Class and Description |
---|
ExecutionService
A Service responsible for providing access to 'system' executors and customer executors.
|
TaskScheduler
ExecutorService can schedule a command to run after a given delay or execute periodically. |
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Class and Description |
---|
CoreService
Marker interface for core Hazelcast services.
|
StatisticsAwareService
A service implementating this interface provides local instance statistics.
|
Copyright © 2021 Hazelcast, Inc.. All Rights Reserved.