Package | Description |
---|---|
com.hazelcast.aggregation.impl | |
com.hazelcast.cache |
This package contains the public API extension for Hazelcast JCache,
the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.event |
Event classes to define listenters for JCache other than EntryListener
|
com.hazelcast.cache.impl.journal | |
com.hazelcast.cache.impl.merge.entry |
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
|
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.record |
Hazelcast JSR-107 aka JCache implementation
Internal record store
|
com.hazelcast.cardinality.impl | |
com.hazelcast.cardinality.impl.hyperloglog |
This package contains spec for the HyperLogLog data-structure.
|
com.hazelcast.cardinality.impl.hyperloglog.impl |
This package contains implementations of
HyperLogLog . |
com.hazelcast.cardinality.impl.operations |
This package contains the operations on the
CardinalityEstimator . |
com.hazelcast.client.impl.operations |
Contains client operations
|
com.hazelcast.client.impl.protocol.task.cache |
Client protocol tasks implementations for JCache
|
com.hazelcast.client.impl.protocol.task.dynamicconfig | |
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
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.txnqueue | |
com.hazelcast.collection.impl.txnqueue.operations | |
com.hazelcast.concurrent.atomiclong.operations |
This package contains the operations on the IAtomicLong.
|
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.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.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.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.ascii.memcache |
This package contains MemoryCache functionality for Hazelcast.
|
com.hazelcast.internal.ascii.rest |
This package contains Reset functionality for Hazelcast.
|
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.dynamicconfig |
Classes related to Dynamic Configuration.
|
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.management.request |
Contains requests that made from Management Center.
|
com.hazelcast.internal.nearcache.impl.invalidation |
Invalidations for Near Cache.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.partition.operation |
Contains the operations for partition package.
|
com.hazelcast.internal.serialization.impl | |
com.hazelcast.internal.usercodedeployment.impl | |
com.hazelcast.internal.usercodedeployment.impl.operation | |
com.hazelcast.journal |
This package contains supporting classes for data structure specific event journals.
|
com.hazelcast.map.eviction |
This package contains eviction specific classes.
|
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.iterator | |
com.hazelcast.map.impl.journal | |
com.hazelcast.map.impl.nearcache.invalidation | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.query | |
com.hazelcast.map.impl.querycache.subscriber.operation |
This package contains Enterprise specific operations for
QueryCache . |
com.hazelcast.map.impl.record |
Contains record specific classes.
|
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.map.impl.wan |
Contains wan replication event classes
|
com.hazelcast.map.merge |
Contains merge policies for
IMap |
com.hazelcast.mapreduce.aggregation.impl |
This package contains a set of predefined aggregation implementations
|
com.hazelcast.mapreduce.impl |
This package contains the default implementation for the map reduce framework
internals.
|
com.hazelcast.mapreduce.impl.notification |
This package contains all remote node notifications
|
com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
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.nio.serialization |
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
|
com.hazelcast.nio.serialization.impl | |
com.hazelcast.projection.impl | |
com.hazelcast.query |
Contains interfaces/classes related to Hazelcast query and indexing support.
|
com.hazelcast.query.impl |
Contains the implementation classes of the query functionality.
|
com.hazelcast.query.impl.predicates | |
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 |
This package contains ScheduledExecutorService functionality for Hazelcast.
The ScheduledExecutorService provides functionality similar to ExecutorService
and also additional methods like executing tasks on a member who is owner of a specific key. |
com.hazelcast.scheduledexecutor.impl | |
com.hazelcast.scheduledexecutor.impl.operations | |
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.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.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.spi.impl.operationservice.impl.responses |
Contains the different responses that can be send as a consequence of an Operation invocation.
|
com.hazelcast.spi.impl.proxyservice.impl.operations |
Contains the operations for the
ProxyServiceImpl . |
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.version |
This package contains classes to support the versioning API.
|
com.hazelcast.wan |
This package contains the WAN replication API
|
Modifier and Type | Class and Description |
---|---|
class |
BigDecimalAverageAggregator<I> |
class |
BigDecimalSumAggregator<I> |
class |
BigIntegerAverageAggregator<I> |
class |
BigIntegerSumAggregator<I> |
class |
CountAggregator<I> |
class |
DistinctValuesAggregator<I,R> |
class |
DoubleAverageAggregator<I> |
class |
DoubleSumAggregator<I> |
class |
FixedSumAggregator<I> |
class |
FloatingPointSumAggregator<I> |
class |
IntegerAverageAggregator<I> |
class |
IntegerSumAggregator<I> |
class |
LongAverageAggregator<I> |
class |
LongSumAggregator<I> |
class |
MaxAggregator<I,R extends Comparable> |
class |
MaxByAggregator<I> |
class |
MinAggregator<I,R extends Comparable> |
class |
MinByAggregator<I> |
class |
NumberAverageAggregator<I> |
Modifier and Type | Class and Description |
---|---|
class |
HazelcastExpiryPolicy
Hazelcast provides overloads of the typical cache operations with a custom
ExpiryPolicy parameter.This class provides a custom implementation of an ExpiryPolicy to
react on all three types of policies:
Create
Access
Update
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheEventData
Internal event data wrapper used during publishing and dispatching events.
|
Modifier and Type | Class and Description |
---|---|
class |
CacheClearResponse
This class is a simple object wrapper to be used by
CacheClearOperation . |
class |
CacheEntryIterationResult
Response data object returned by
CacheEntryIteratorOperation . |
class |
CacheEventDataImpl
Implementation of
CacheEventData . |
class |
CacheEventListenerAdaptor<K,V>
This implementation of
CacheEventListener uses the adapter pattern for wrapping all cache event listener
types into a single listener. |
class |
CacheEventSet
Internal Set wrapper of
CacheEventData items used during publishing and dispatching events. |
class |
CacheKeyIterationResult
Response data object returned by
CacheKeyIteratorOperation . |
class |
CachePartitionEventData |
class |
PreJoinCacheConfig<K,V>
This subclass of
CacheConfig is used to communicate cache configurations in pre-join cache operations when cluster
version is at least 3.9. |
Modifier and Type | Class and Description |
---|---|
class |
CachePartitionLostEventFilter
Used to filter partition lost listener events
|
Modifier and Type | Class and Description |
---|---|
class |
CacheEventJournalReadOperation<K,V,T>
Reads from the cache event journal in batches.
|
class |
CacheEventJournalReadResultSetImpl<K,V,T> |
class |
CacheEventJournalSubscribeOperation
Performs the initial subscription to the cache event journal.
|
class |
DeserializingEventJournalCacheEvent<K,V> |
class |
InternalEventJournalCacheEvent
The event journal item for map events.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultCacheEntryView
Default heap based implementation of
CacheEntryView . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCacheOperation
Base Cache Operation.
|
class |
AbstractMutatingCacheOperation
Base class for all mutable cache operations.
|
class |
CacheBackupEntryProcessorOperation
Operation of the Cache Backup Entry Processor.
|
class |
CacheClearBackupOperation
Backup operation of
CacheClearOperation . |
class |
CacheClearOperation
Cache Clear will clear all internal cache data without sending any event
|
class |
CacheClearOperationFactory
OperationFactory implementation for Clear Operations. |
class |
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key.
|
class |
CacheCreateConfigOperation
Used to create cluster wide cache configuration.
|
class |
CacheDestroyOperation
Destroys the cache on the cluster or on a single node by calling
ICacheService.deleteCache(String, String, boolean) . |
class |
CacheEntryIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheEntryProcessorOperation
Operation of the Cache Entry Processor.
|
class |
CacheGetAllOperation
Gets all keys from the cache.
|
class |
CacheGetAllOperationFactory
Factory implementation for
CacheGetAllOperation . |
class |
CacheGetAndRemoveOperation
Cache GetAndRemove Operation.
|
class |
CacheGetAndReplaceOperation
Cache GetAndReplace Operation.
|
class |
CacheGetConfigOperation
Cache GetConfig Operation.
|
class |
CacheGetInvalidationMetaDataOperation |
static class |
CacheGetInvalidationMetaDataOperation.MetaDataResponse |
class |
CacheGetOperation
Cache Get Operation.
|
class |
CacheKeyIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheListenerRegistrationOperation
Listener can be registered and unregistered by
CacheService . |
class |
CacheLoadAllOperation
Loads all entries of the keys to partition record store
ICacheRecordStore . |
class |
CacheLoadAllOperationFactory
Factory implementation for
CacheLoadAllOperation . |
class |
CacheManagementConfigOperation
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and
statistics mxbeans of the cache.
|
class |
CacheMergeOperation |
class |
CacheNearCacheStateHolder
Holder for Near Cache metadata.
|
class |
CachePutAllBackupOperation
Cache PutAllBackup Operation is the backup operation used by load all operation.
|
class |
CachePutAllOperation |
class |
CachePutBackupOperation
Backup operation for the operation of adding cache entries into record stores.
|
class |
CachePutIfAbsentOperation
Operation implementation for calling
ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int) . |
class |
CachePutOperation
Operation implementation for
ICacheRecordStore.put(Data, Object, ExpiryPolicy, String, int) and
ICacheRecordStore.getAndPut(Data, Object, ExpiryPolicy, String, int) . |
class |
CacheRemoveAllBackupOperation
Backup operation of
CacheRemoveAllOperation . |
class |
CacheRemoveAllOperation
TODO add a proper JavaDoc
|
class |
CacheRemoveAllOperationFactory
OperationFactory implementation for RemoveAll Operations. |
class |
CacheRemoveBackupOperation
Backup operation used by remove operations.
|
class |
CacheRemoveOperation
Operation implementation for cache remove functionality.
|
class |
CacheReplaceOperation
Operator implementation for cache replace functionality.
|
class |
CacheReplicationOperation
Replication operation is the data migration operation of
CacheRecordStore . |
class |
CacheSizeOperation
This operation implementation is for calculating the cluster size of a named cache.
|
class |
CacheSizeOperationFactory
Factory implementation of
CacheSizeOperation . |
class |
OnJoinCacheOperation
Operation executed on joining members so they become aware of
CacheConfig s dynamically created via
CacheManager.createCache(String, Configuration) . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCacheRecord<V>
Abstract implementation of
CacheRecord with key, value and
expiration time as internal state. |
class |
CacheDataRecord
Implementation of
CacheRecord where value has an internal serialized format. |
class |
CacheObjectRecord
Implementation of
CacheRecord which has an internal object format. |
Modifier and Type | Class and Description |
---|---|
class |
CardinalityEstimatorContainer |
Modifier and Type | Interface and Description |
---|---|
interface |
HyperLogLog
HyperLogLog is a redundant and highly available distributed data-structure used for cardinality estimation
purposes on unique items in significantly sized data cultures.
|
Modifier and Type | Interface and Description |
---|---|
interface |
HyperLogLogEncoder |
Modifier and Type | Class and Description |
---|---|
class |
DenseHyperLogLogEncoder
1.
|
class |
HyperLogLogImpl |
class |
SparseHyperLogLogEncoder
1.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCardinalityEstimatorOperation |
class |
AggregateBackupOperation |
class |
AggregateOperation |
class |
CardinalityEstimatorBackupAwareOperation |
class |
EstimateOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractClientOperation |
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
GetConnectedClientsOperation |
class |
OperationFactoryWrapper |
class |
PostJoinClientOperation |
Modifier and Type | Class and Description |
---|---|
class |
CacheAssignAndGetUuidsOperation |
class |
CacheAssignAndGetUuidsOperationFactory |
Modifier and Type | Method and Description |
---|---|
protected IdentifiedDataSerializable |
AddQueueConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddLockConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddEventJournalConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddCacheConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddSemaphoreConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddSetConfigMessageTask.getConfig() |
protected abstract IdentifiedDataSerializable |
AbstractAddConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddExecutorConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddScheduledExecutorConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddRingbufferConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddMultiMapConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddReplicatedMapConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddDurableExecutorConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddMapConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddReliableTopicConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddListConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddCardinalityEstimatorConfigMessageTask.getConfig() |
protected IdentifiedDataSerializable |
AddTopicConfigMessageTask.getConfig() |
Modifier and Type | Class and Description |
---|---|
class |
MapAssignAndGetUuidsOperation |
class |
MapAssignAndGetUuidsOperationFactory |
Modifier and Type | Class and Description |
---|---|
class |
CollectionContainer |
class |
CollectionEvent |
class |
CollectionEventFilter |
class |
CollectionItem |
class |
TxCollectionItem |
Modifier and Type | Class and Description |
---|---|
class |
CollectionAddAllBackupOperation |
class |
CollectionAddAllOperation |
class |
CollectionAddBackupOperation |
class |
CollectionAddOperation |
class |
CollectionBackupAwareOperation |
class |
CollectionClearBackupOperation |
class |
CollectionClearOperation |
class |
CollectionCompareAndRemoveOperation |
class |
CollectionContainsOperation |
class |
CollectionGetAllOperation |
class |
CollectionIsEmptyOperation |
class |
CollectionOperation |
class |
CollectionRemoveBackupOperation |
class |
CollectionRemoveOperation |
class |
CollectionReplicationOperation |
class |
CollectionSizeOperation |
Modifier and Type | Class and Description |
---|---|
class |
ListContainer |
Modifier and Type | Class and Description |
---|---|
class |
ListAddAllOperation |
class |
ListAddOperation |
class |
ListGetOperation |
class |
ListIndexOfOperation |
class |
ListRemoveOperation |
class |
ListReplicationOperation |
class |
ListSetBackupOperation |
class |
ListSetOperation |
class |
ListSubOperation |
Modifier and Type | Class and Description |
---|---|
class |
QueueContainer
The
QueueContainer contains the actual queue and provides functionalities such as :
queue functionalities
transactional operation functionalities
schedules queue destruction if it is configured to be destroyed once empty
|
class |
QueueEvent
Used for queue-wide events.
|
class |
QueueEventFilter
Provides the filtering functionality for Queue events.
|
class |
QueueItem
Queue Item.
|
Modifier and Type | Class and Description |
---|---|
class |
CheckAndEvictOperation
Provides eviction functionality for Operations of Queue.
|
class |
ClearBackupOperation
Store items' ID as set when ClearOperation run.
|
class |
ClearOperation
Clears items stored by Queue.
|
class |
CompareAndRemoveBackupOperation
This class triggers backup method for items' ID.
|
class |
CompareAndRemoveOperation
This class triggers iterator and if find same item in the Queue, remove this item.
|
class |
ContainsOperation
Checks whether contain or not item in the Queue.
|
class |
DrainBackupOperation
This class stores items' ID when DrainOperation run.
|
class |
DrainOperation
This class drain items according to drain condition.
|
class |
IsEmptyOperation
check if queue is empty
|
class |
IteratorOperation
Provides iterator functionality for Queue.
|
class |
OfferBackupOperation
Backup items during offer operation.
|
class |
OfferOperation
Contains offer operation for the Queue.
|
class |
PeekOperation
Peek operation for Queue.
|
class |
PollBackupOperation
Backup items during pool operation.
|
class |
PollOperation
Pool operation for Queue.
|
class |
QueueBackupAwareOperation
This abstract class contains important methods for all Queue operations.
|
class |
QueueOperation
This class contains methods for Queue operations
such as
AddAllOperation . |
class |
QueueReplicationOperation
Replication operation for the Queue.
|
class |
RemainingCapacityOperation
Returns the remaining capacity of the queue based on config max-size
|
class |
RemoveBackupOperation
Remove backup of the Queue item.
|
class |
RemoveOperation
Remove operation for the Queue.
|
class |
SizeOperation
Notify size of the queue.
|
Modifier and Type | Class and Description |
---|---|
class |
SetContainer |
Modifier and Type | Class and Description |
---|---|
class |
SetReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
CollectionTransactionLogRecord
This class contains Transaction log for the Collection.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionCommitBackupOperation
a wrapper for running all commit backup operations at once
|
class |
CollectionCommitOperation
a wrapper for running all commit operations at once
|
class |
CollectionPrepareBackupOperation |
class |
CollectionPrepareOperation |
class |
CollectionReserveAddOperation |
class |
CollectionReserveRemoveOperation |
class |
CollectionRollbackBackupOperation |
class |
CollectionRollbackOperation |
class |
CollectionTransactionRollbackOperation |
class |
CollectionTxnAddBackupOperation |
class |
CollectionTxnAddOperation |
class |
CollectionTxnRemoveBackupOperation |
class |
CollectionTxnRemoveOperation |
Modifier and Type | Class and Description |
---|---|
class |
QueueTransactionLogRecord
This class contains Transaction log for the Queue.
|
class |
TxQueueItem
Transactional Queue Item.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseTxnQueueOperation |
class |
QueueTransactionRollbackOperation
Transaction Rollback Operation for the Queue.
|
class |
TxnCommitBackupOperation
a wrapper for running all commit backup operations at once
|
class |
TxnCommitOperation
a wrapper for running all commit operations at once
|
class |
TxnOfferBackupOperation
Provides backup operation during transactional offer operation.
|
class |
TxnOfferOperation
Transaction commit operation for a queue offer, executed on the primary replica.
|
class |
TxnPeekOperation
Peek operation for the transactional queue.
|
class |
TxnPollBackupOperation
Provides backup operation during transactional poll operation.
|
class |
TxnPollOperation
Poll operation for the transactional queue.
|
class |
TxnPrepareBackupOperation
Provides backup operation during transactional prepare operation.
|
class |
TxnPrepareOperation
Prepare operation for the transactional queue.
|
class |
TxnReserveOfferBackupOperation
Transaction prepare operation for a queue offer, executed on the backup replica.
|
class |
TxnReserveOfferOperation
Transaction prepare operation for a queue offer, executed on the primary replica.
|
class |
TxnReservePollBackupOperation
Transaction prepare operation for a queue poll, executed on the backup replica.
|
class |
TxnReservePollOperation
Transaction prepare operation for a queue poll, executed on the primary replica.
|
class |
TxnRollbackBackupOperation
Provides backup operation during transactional rollback operation.
|
class |
TxnRollbackOperation
Rollback operation for the transactional queue.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAtomicLongOperation |
class |
AddAndGetOperation |
class |
AtomicLongBackupAwareOperation |
class |
AtomicLongReplicationOperation |
class |
GetAndAddOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAlterOperation |
class |
AbstractAtomicReferenceOperation |
class |
AlterAndGetOperation |
class |
AlterOperation |
class |
ApplyOperation |
class |
AtomicReferenceBackupAwareOperation |
class |
AtomicReferenceReplicationOperation |
class |
CompareAndSetOperation |
class |
GetAndAlterOperation |
class |
GetAndSetOperation |
class |
IsNullOperation |
class |
SetAndGetOperation |
class |
SetBackupOperation |
Modifier and Type | Class and Description |
---|---|
class |
CountDownLatchContainer |
Modifier and Type | Class and Description |
---|---|
class |
AwaitOperation |
class |
CountDownLatchBackupOperation |
class |
CountDownLatchReplicationOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
Modifier and Type | Class and Description |
---|---|
class |
LockStoreImpl |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLockOperation |
class |
AwaitBackupOperation |
class |
BeforeAwaitBackupOperation |
class |
BeforeAwaitOperation |
class |
GetLockCountOperation |
class |
GetRemainingLeaseTimeOperation |
class |
IsLockedOperation |
class |
LocalLockCleanupOperation |
class |
LockBackupOperation |
class |
LockOperation |
class |
LockReplicationOperation |
class |
SignalBackupOperation |
class |
SignalOperation |
class |
UnlockBackupOperation |
class |
UnlockIfLeaseExpiredOperation |
class |
UnlockOperation |
Modifier and Type | Class and Description |
---|---|
class |
SemaphoreContainer |
Modifier and Type | Class and Description |
---|---|
class |
AcquireBackupOperation |
class |
AcquireOperation |
class |
AvailableOperation |
class |
InitBackupOperation |
class |
InitOperation |
class |
ReduceBackupOperation |
class |
ReduceOperation |
class |
ReleaseBackupOperation |
class |
ReleaseOperation |
class |
SemaphoreBackupAwareOperation |
class |
SemaphoreBackupOperation |
class |
SemaphoreDetachMemberBackupOperation |
class |
SemaphoreDetachMemberOperation |
class |
SemaphoreOperation |
class |
SemaphoreReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
CachePartitionLostListenerConfig
Configuration for CachePartitionLostListener
|
class |
CachePartitionLostListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
CacheSimpleConfig
Simple configuration to hold parsed XML configuration.
|
static class |
CacheSimpleConfig.ExpiryPolicyFactoryConfig
Represents configuration for "ExpiryPolicyFactory".
|
static class |
CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
Represents duration configuration with duration amount and time unit
for the "TimedExpiryPolicyFactoryConfig".
|
static class |
CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
|
class |
CacheSimpleConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
CacheSimpleEntryListenerConfig
Simple configuration to hold parsed listener config.
|
class |
CacheSimpleEntryListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
CardinalityEstimatorConfig
Configuration options for the
CardinalityEstimator |
class |
CollectionConfig<T extends CollectionConfig>
Provides configuration service for Collection.
|
class |
DurableExecutorConfig
Contains the configuration for an
DurableExecutorService . |
class |
EntryListenerConfig
Configuration for EntryListener
|
static class |
EntryListenerConfig.MapListenerToEntryListenerAdapter
Wraps a MapListener into an EntryListener.
|
class |
EntryListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
EventJournalConfig
Configuration for an event journal.
|
class |
ExecutorConfig
Contains the configuration for an
IExecutorService . |
class |
ExecutorConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
HotRestartConfig
Configures the Hot Restart Persistence per Hazelcast data structure.
|
class |
ItemListenerConfig
Contains the configuration for an Item Listener.
|
class |
ItemListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
ListConfig
Contains the configuration for an
IList . |
class |
ListConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
ListenerConfig
Contains the configuration for an
EventListener . |
class |
ListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
LockConfig
Contains the configuration for the
ILock . |
class |
MapAttributeConfig
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
|
class |
MapAttributeConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapConfig
Contains the configuration for an
IMap . |
class |
MapConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapIndexConfig
Contains the configuration for an index in a map.
|
class |
MapIndexConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapPartitionLostListenerConfig
Configuration for MapPartitionLostListener
|
class |
MapPartitionLostListenerConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MapStoreConfig
Contains the configuration for a Map Store.
|
class |
MapStoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
MultiMapConfig
Configuration for MultiMap.
|
class |
MultiMapConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
NearCacheConfig
Contains the configuration for a Near Cache.
|
class |
NearCacheConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
NearCachePreloaderConfig
Configuration for eviction.
|
class |
PartitioningStrategyConfig
Contains the configuration for partitioning strategy.
|
class |
PartitioningStrategyConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
PredicateConfig
Contains the configuration for an
Predicate . |
class |
QueryCacheConfig
Contains configuration for
QueryCache . |
class |
QueueConfig
Contains the configuration for an
IQueue . |
class |
QueueConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
QueueStoreConfig
Configuration for the
QueueStore . |
class |
QueueStoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
QuorumConfig
Contains the configuration for cluster quorum.
|
class |
QuorumListenerConfig
Confiquration class for
QuorumListener |
class |
ReliableTopicConfig
Configuration for a reliable
ITopic . |
class |
ReplicatedMapConfig
Contains the configuration for an
ReplicatedMap |
class |
RingbufferConfig
Contains the configuration for the
Ringbuffer . |
class |
RingbufferStoreConfig
Configuration for the
RingbufferStore . |
class |
ScheduledExecutorConfig
Configuration options for the
IScheduledExecutorService . |
class |
SemaphoreConfig
Contains the configuration for an
ISemaphore . |
class |
SemaphoreConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
SetConfig
Contains the configuration for an
ISet . |
class |
SetConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
TopicConfig
Contains the configuration for a
ITopic . |
class |
TopicConfigReadOnly
Deprecated.
this class will be removed in 4.0; it is meant for internal usage only.
|
class |
WanConsumerConfig
Config to be used by WanReplicationConsumer instances (EE only).
|
class |
WanPublisherConfig
Configuration object for WAN publishers.
|
class |
WanReplicationConfig
Configuration for WAN replication.
|
Modifier and Type | Class and Description |
---|---|
class |
DisposeResultBackupOperation |
class |
DisposeResultOperation |
class |
PutResultBackupOperation |
class |
PutResultOperation |
class |
RetrieveAndDisposeResultOperation |
class |
RetrieveResultOperation
Used to retrieve the response of an execution with the given sequence
|
class |
ShutdownOperation |
class |
TaskBackupOperation |
class |
TaskOperation |
Modifier and Type | Class and Description |
---|---|
class |
RunnableAdapter<V>
|
Modifier and Type | Class and Description |
---|---|
class |
CallableTaskOperation |
class |
CancellationOperation |
class |
MemberCallableTaskOperation |
Modifier and Type | Class and Description |
---|---|
class |
MemberImpl |
Modifier and Type | Class and Description |
---|---|
class |
MemcacheEntry |
Modifier and Type | Class and Description |
---|---|
class |
RestValue |
Modifier and Type | Class and Description |
---|---|
class |
MemberInfo |
Modifier and Type | Class and Description |
---|---|
class |
BindMessage |
class |
ClusterStateChange<T>
Wrapper object indicating a change in the cluster state - it may be cluster state change or cluster version change.
|
class |
ClusterStateTransactionLogRecord
TransactionLogRecord implementation to be used in
ClusterState transactions. |
class |
ConfigCheck
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations
don't join.
|
class |
JoinMessage |
class |
JoinRequest |
class |
MembersView
MembersView is a container object to carry member list and version together.
|
class |
MembersViewMetadata |
class |
SplitBrainJoinMessage
A
JoinMessage issued by the master node of a subcluster to the master of another subcluster
while searching for other clusters for split brain recovery. |
Modifier and Type | Interface and Description |
---|---|
interface |
JoinOperation
Marker interface for join and post-join operations.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractJoinOperation |
class |
AuthenticationFailureOp |
class |
AuthorizationOp |
class |
BeforeJoinCheckFailureOp |
class |
CommitClusterStateOp |
class |
ConfigMismatchOp
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
|
class |
ExplicitSuspicionOp
An operation which is sent by a member that wants to be explicitly suspected by the target.
|
class |
FetchMembersViewOp
An operation sent by the member that starts mastership claim process to fetch/gather member views of other members.
|
class |
FinalizeJoinOp
Sent by the master to all members to finalize the join operation from a joining/returning node.
|
class |
GroupMismatchOp |
class |
HeartbeatComplaintOp |
class |
HeartbeatOp
A heartbeat sent from one cluster member to another.
|
class |
JoinMastershipClaimOp |
class |
JoinRequestOp |
class |
LockClusterStateOp |
class |
MasterConfirmationOp |
class |
MasterResponseOp
Operation sent by any node to set the master address on the receiver
|
class |
MemberAttributeChangedOp |
class |
MemberRemoveOperation
Deprecated.
|
class |
MembersUpdateOp |
class |
MergeClustersOp |
class |
OnJoinOp |
class |
PromoteLiteMemberOp
Promotes caller lite member to a normal member.
|
class |
RollbackClusterStateOp |
class |
ShutdownNodeOp |
class |
SplitBrainMergeValidationOp
Validate whether clusters may merge to recover from a split brain, based on configuration & cluster version.
|
class |
TriggerExplicitSuspicionOp
An operation which is sent to trigger
ExplicitSuspicionOp on target member. |
class |
TriggerMemberListPublishOp
Requests member list publish from master node
|
class |
WhoisMasterOp |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDynamicConfigOperation |
class |
AddDynamicConfigOperation |
class |
DynamicConfigPreJoinOperation |
Modifier and Type | Method and Description |
---|---|
void |
ClusterWideConfigurationService.broadcastConfig(IdentifiedDataSerializable config) |
void |
ConfigurationService.broadcastConfig(IdentifiedDataSerializable config)
Register a dynamic configurations to all cluster members.
|
ICompletableFuture<Object> |
ClusterWideConfigurationService.broadcastConfigAsync(IdentifiedDataSerializable config) |
void |
ClusterWideConfigurationService.registerConfigLocally(IdentifiedDataSerializable newConfig,
ConfigCheckMode configCheckMode)
Register a dynamic configuration in a local member.
|
Constructor and Description |
---|
AddDynamicConfigOperation(IdentifiedDataSerializable config,
int memberListVersion) |
AddDynamicConfigOperationSupplier(ClusterService clusterService,
IdentifiedDataSerializable config) |
DynamicConfigPreJoinOperation(IdentifiedDataSerializable[] configs,
ConfigCheckMode configCheckMode) |
Modifier and Type | Class and Description |
---|---|
class |
MapConfigDTO
Serializable adapter for
MapConfig |
class |
PermissionConfigDTO
DTO object that provides serialization/deserialization support
for
PermissionConfig |
Modifier and Type | Class and Description |
---|---|
class |
AbstractManagementOperation |
class |
AddWanConfigOperation
Operation to add a new
WanReplicationConfig at runtime. |
class |
ChangeWanStateOperation
Enables/Disable publishing events to target cluster in WAN Replication
WanReplicationService
on a node. |
class |
ClearWanQueuesOperation
Clear WAN replication queues for the given wan replication schema and publisher
|
class |
GetMapConfigOperation
Operation to fetch Map configuration.
|
class |
ScriptExecutorOperation
Operation to execute script on the node.
|
class |
ThreadDumpOperation
Operation for generating thread dumps.
|
class |
UpdateManagementCenterUrlOperation
Operation to update Management Center URL configured on the node.
|
class |
UpdateMapConfigOperation
Operation to update map configuration from Management Center.
|
class |
UpdatePermissionConfigOperation
Propagates
PermissionConfig changes to members. |
Modifier and Type | Class and Description |
---|---|
static class |
GetCacheEntryRequest.CacheBrowserEntryView |
static class |
GetCacheEntryRequest.GetCacheEntryViewEntryProcessor |
Modifier and Type | Class and Description |
---|---|
class |
BatchNearCacheInvalidation |
class |
Invalidation
Root interface for Near Cache invalidation data.
|
class |
SingleNearCacheInvalidation
Represents a single key invalidation.
|
Modifier and Type | Class and Description |
---|---|
class |
MigrationInfo |
class |
NonFragmentedServiceNamespace
Internal
ServiceNamespace implementation used by partitioning system to identify
non-fragmented service structures. |
class |
PartitionRuntimeState |
class |
ReplicaFragmentMigrationState
Contains fragment namespaces along with their partition versions and migration data operations
|
Modifier and Type | Class and Description |
---|---|
class |
AssignPartitions
Sent from non-master nodes to the master to initialize the partition assignment.
|
class |
FetchPartitionStateOperation
Operation sent by the master to the cluster members to fetch their partition state.
|
class |
FinalizeMigrationOperation
Invoked locally on the source or destination of the migration to finalize the migration.
|
class |
HasOngoingMigration |
class |
LegacyMigrationOperation
Migration operation used before Hazelcast version 3.9
It runs on the migration destination and applies the received partition data in one shot.
|
class |
LegacyMigrationRequestOperation
Migration request operation used before Hazelcast version 3.9
It runs on the migration source and transfers the whole partition data in one shot.
|
class |
MigrationCommitOperation
Sent by the master node to commit a migration on the migration destination.
|
class |
MigrationOperation
Migration operation used by Hazelcast version 3.9
It runs on the migration destination and applies the received fragments.
|
class |
MigrationRequestOperation
Migration request operation used by Hazelcast version 3.9
Sent from the master node to the partition owner.
|
class |
PartitionBackupReplicaAntiEntropyOperation |
class |
PartitionReplicaSyncRequest
The request sent from a replica to the partition owner to synchronize the replica data.
|
class |
PartitionReplicaSyncResponse
The replica synchronization response sent from the partition owner to a replica.
|
class |
PartitionReplicaSyncRetryResponse
The response to a
PartitionReplicaSyncRequest that the replica should retry. |
class |
PartitionStateOperation
Sent from the master to publish or sync the partition table state to all cluster members.
|
class |
PromotionCommitOperation
Used for committing a promotion on destination.
|
class |
SafeStateCheckOperation
Checks whether a node is safe or not.
|
class |
ShutdownRequestOperation |
class |
ShutdownResponseOperation |
Modifier and Type | Method and Description |
---|---|
IdentifiedDataSerializable |
ArrayDataSerializableFactory.create(int typeId) |
IdentifiedDataSerializable |
ArrayDataSerializableFactory.create(int typeId,
Version version) |
Modifier and Type | Class and Description |
---|---|
class |
ClassData
Carries byte code of a class along with its inner classes.
|
Modifier and Type | Class and Description |
---|---|
class |
ClassDataFinderOperation |
class |
DeployClassesOperation
Operation to distribute class definitions uploaded from client to cluster
|
Modifier and Type | Class and Description |
---|---|
class |
EventJournalInitialSubscriberState
The response for the event journal subcription.
|
class |
EventJournalReadOperation<T,J>
Reads from the map event journal in batches.
|
Modifier and Type | Class and Description |
---|---|
class |
LFUEvictionPolicy
LFU eviction policy for an
IMap |
class |
LRUEvictionPolicy
LRU eviction policy for an
IMap |
class |
RandomEvictionPolicy
Random eviction policy for an
IMap |
Modifier and Type | Class and Description |
---|---|
class |
EntryEventFilter
Event filter which matches events for a specified entry key.
|
class |
EntryRemovingProcessor |
class |
EventListenerFilter
Event filter matching events of specified types.
|
class |
LazyMapEntry<K,V>
A
Map.Entry implementation which serializes/de-serializes key and value objects on demand. |
class |
LockAwareLazyMapEntry
Specialization of the LazyMapEntry that is LockAware.
|
class |
MapEntries
|
class |
MapKeySet |
class |
MapPartitionLostEventFilter |
class |
MapValueCollection |
class |
SimpleEntryView<K,V>
SimpleEntryView is an implementation of
EntryView and also it is writable. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCursor<T>
Base class for a cursor class holding a collection of items and the next position from which to resume fetching.
|
class |
MapEntriesWithCursor
Container class for a collection of entries along with an offset from which new entries can be fetched.
|
class |
MapKeysWithCursor
Container class for a collection of keys along with an offset from which new keys can be fetched.
|
Modifier and Type | Class and Description |
---|---|
class |
DeserializingEventJournalMapEvent<K,V> |
class |
InternalEventJournalMapEvent
The event journal item for map events.
|
class |
MapEventJournalReadOperation<K,V,T>
Reads from the map event journal in batches.
|
class |
MapEventJournalReadResultSetImpl<K,V,T> |
class |
MapEventJournalSubscribeOperation
Performs the initial subscription to the map event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
UuidFilter
Compares supplied uuid with this filters' uuid to prevent unneeded delivery of an invalidation event to operation caller.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMapOperationFactory |
class |
AccumulatorConsumerOperation
Processes remaining items in
Accumulator instances on a partition. |
class |
AddIndexOperation |
class |
AddIndexOperationFactory |
class |
AddInterceptorOperation |
class |
AwaitMapFlushOperation
IMap.flush() call waits the end of flush by using this operation. |
class |
BasePutOperation |
class |
BaseRemoveOperation |
class |
ClearExpiredOperation
Clears expired records.
|
class |
ClearNearCacheOperation
Deprecated.
|
class |
ClearOperationFactory |
class |
ContainsKeyOperation |
class |
ContainsValueOperation |
class |
ContainsValueOperationFactory |
class |
DeleteOperation |
class |
EntryBackupOperation |
class |
EntryOffloadableSetUnlockOperation
Set & Unlock processing for the EntryOperation
See the javadoc on
EntryOperation |
class |
EntryOperation
Contains implementation of the off-loadable contract for EntryProcessor execution on a single key.
|
class |
EvictAllBackupOperation
Operation which evicts all keys except locked ones.
|
class |
EvictAllOperation
Operation which evicts all keys except locked ones.
|
class |
EvictAllOperationFactory
Operation factory for evict all operations.
|
class |
EvictBackupOperation |
class |
EvictBatchBackupOperation
Used to transfer expired keys from owner replica to backup replicas.
|
class |
EvictOperation |
class |
GetEntryViewOperation |
class |
GetOperation |
class |
IsEmptyOperationFactory |
class |
IsKeyLoadFinishedOperation |
class |
IsPartitionLoadedOperation |
class |
IsPartitionLoadedOperationFactory |
class |
KeyLoadStatusOperation
Notifies RecordStores about completion of loading
|
class |
KeyLoadStatusOperationFactory
Factory for
KeyLoadStatusOperation |
class |
LoadAllOperation
Triggers map store load of all given keys.
|
class |
LoadMapOperation
Triggers map loading from a map store
|
class |
LockAwareOperation |
class |
MapFetchEntriesOperation
Operation for fetching a chunk of entries from a single
IMap partition. |
class |
MapFetchKeysOperation
Operation for fetching a chunk of keys from a single
IMap partition. |
class |
MapFetchWithQueryOperation
Fetches by query a batch of
fetchSize items from a single partition ID for a map. |
class |
MapFlushBackupOperation
Empties backup write-behind-queues upon
IMap.flush() |
class |
MapFlushOperation
Flushes dirty entries upon call of
IMap.flush() |
class |
MapFlushOperationFactory |
class |
MapGetAllOperationFactory |
class |
MapGetInvalidationMetaDataOperation |
static class |
MapGetInvalidationMetaDataOperation.MetaDataResponse |
class |
MapIsEmptyOperation |
class |
MapLoadAllOperationFactory
Operation factory for load all operations.
|
class |
MapNearCacheStateHolder
Holder for Near Cache metadata.
|
class |
MapOperation |
class |
MapReplicationOperation
Replicates all IMap-states of this partition to a replica partition.
|
class |
MapReplicationStateHolder
Holder for raw IMap key-value pairs and their metadata.
|
class |
MapSizeOperation |
class |
MergeOperation |
class |
MultipleEntryBackupOperation |
class |
MultipleEntryOperation |
class |
MultipleEntryOperationFactory |
class |
MultipleEntryWithPredicateBackupOperation |
class |
MultipleEntryWithPredicateOperation |
class |
MutatingKeyBasedMapOperation |
class |
NotifyMapFlushOperation
|
class |
PartitionWideEntryBackupOperation |
class |
PartitionWideEntryOperation
GOTCHA: This operation does NOT load missing keys from map-store for now.
|
class |
PartitionWideEntryOperationFactory |
class |
PartitionWideEntryWithPredicateBackupOperation |
class |
PartitionWideEntryWithPredicateOperation |
class |
PartitionWideEntryWithPredicateOperationFactory |
class |
PostJoinMapOperation |
static class |
PostJoinMapOperation.InterceptorInfo |
class |
PutAllBackupOperation |
class |
PutAllOperation
Inserts the
MapEntries for a single partition to the local RecordStore . |
class |
PutAllPartitionAwareOperationFactory
Inserts the
MapEntries for all partitions of a member via locally invoked PutAllOperation . |
class |
PutFromLoadAllBackupOperation
Runs on backups.
|
class |
PutFromLoadAllOperation
Puts records to map which are loaded from map store by
IMap.loadAll(boolean) |
class |
PutIfAbsentOperation |
class |
PutTransientOperation |
class |
ReadonlyKeyBasedMapOperation
Abstract
MapOperation that serves as based for readonly operations. |
class |
RemoveFromLoadAllOperation
Removes keys that are contained in the
RecordStore from the provided list,
leaving only keys which are not contained in the record store. |
class |
RemoveIfSameOperation |
class |
RemoveInterceptorOperation |
class |
ReplaceIfSameOperation |
class |
ReplaceOperation |
class |
SetOperation |
class |
SizeOperationFactory |
class |
TriggerLoadIfNeededOperation
Triggers key loading on member with SENDER or SENDER_BACKUP key loader role, if keys have not finished loading yet.
|
class |
TryPutOperation |
class |
TryRemoveOperation |
class |
WriteBehindStateHolder
Holder for write-behind-specific state.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Result<T extends Result>
Result of a Query.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregationResult
Contains the result of the evaluation of an aggregation on a specific Partition or Node.
|
class |
Query
Object representing a Query together with all possible co-variants: like a predicate, iterationType, etc.
|
class |
QueryEventFilter
Event filter which mathes map events on a specified entry key and matching a predefined
Predicate . |
class |
QueryOperation
Native handling only for RU compatibility purposes, can be deleted in 3.10 master
An old member may send a QueryOperation (and not HDQueryOperation) to an HD member.
|
class |
QueryPartitionOperation |
class |
QueryResult
Contains the result of a query or projection evaluation.
|
class |
QueryResultRow
This interfaces provides methods related to entry of the query result.
|
class |
ResultSegment
Represents a partial query result on a segment of the map.
|
class |
Target
Target for a query.
|
Modifier and Type | Class and Description |
---|---|
class |
DestroyQueryCacheOperation
This operation removes all
QueryCache resources on a node. |
class |
MadePublishableOperation
Sets
AccumulatorInfo.publishable to true . |
class |
MadePublishableOperationFactory
Operation factory for
MadePublishableOperation . |
class |
PublisherCreateOperation
An idempotent create operation which creates publisher side functionality.
|
class |
ReadAndResetAccumulatorOperation
Reads all available items from the accumulator of the partition and resets it.
|
class |
SetReadCursorOperation
Sets read cursor of
Accumulator in this partition to the supplied sequence number. |
Modifier and Type | Class and Description |
---|---|
class |
RecordInfo
Record info.
|
class |
RecordReplicationInfo |
Modifier and Type | Class and Description |
---|---|
class |
MapTransactionLogRecord
Represents an operation on the map in the transaction log.
|
class |
TxnDeleteOperation
Transactional delete operation
|
class |
TxnSetOperation
An operation to unlock and set (key,value) on the partition .
|
class |
TxnUnlockBackupOperation
An operation to unlock key on the backup owner.
|
class |
TxnUnlockOperation
An operation to unlock key on the partition owner.
|
class |
VersionedValue
Wrapper for
Data value objects with version information. |
Modifier and Type | Class and Description |
---|---|
class |
MapReplicationRemove |
class |
MapReplicationUpdate |
Modifier and Type | Class and Description |
---|---|
class |
HigherHitsMapMergePolicy
HigherHitsMapMergePolicy causes the merging entry to be merged from source to destination map
if source entry has more hits than the destination one.
|
class |
IgnoreMergingEntryMapMergePolicy
IgnoreMergingEntryMapMergePolicy causes the merging entry to be ignored while collecting merge-needed entries on merging side
Its operations are not implemented since it is only used as a marker
|
class |
LatestUpdateMapMergePolicy
LatestUpdateMapMergePolicy causes the merging entry to be merged from source to destination map
if source entry has updated more recently than the destination entry.
|
class |
PassThroughMergePolicy
PassThroughMergePolicy causes the merging entry to be merged from source to destination map
unless merging entry is null.
|
class |
PutIfAbsentMapMergePolicy
PutIfAbsentMapMergePolicy causes the merging entry to be merged from source to destination map
if it does not exist in the destination map.
|
Modifier and Type | Class and Description |
---|---|
class |
AcceptAllSupplier<KeyIn,ValueIn,ValueOut>
A standard implementation of the
Supplier
interface which accepts all input values and may apply a given
PropertyExtractor on those. |
class |
AvgTuple<F,S>
Internal tuple type for average calculations, used to transmit data between
Combiner and Reducer implementations.
|
class |
KeyPredicateSupplier<KeyIn,ValueIn,ValueOut>
The default supplier for
KeyPredicate s, used
to filter and optionally transform data (using the given
Supplier ). |
class |
PredicateSupplier<KeyIn,ValueIn,ValueOut>
|
class |
SetAdapter<E>
A simple adapter class to serialize values of a
Set using
Hazelcast serialization support. |
Modifier and Type | Class and Description |
---|---|
class |
CombinerResultList<E>
|
class |
HashMapAdapter<K,V>
Simple HashMap adapter class to implement DataSerializable serialization semantics
to not loose hands on serialization while sending intermediate results.
|
class |
ListKeyValueSource<V>
This
KeyValueSource implementation is used in
KeyValueSource.fromList(com.hazelcast.core.IList) to generate a default
implementation based on a Hazelcast IList . |
class |
MapKeyValueSource<K,V>
This
KeyValueSource implementation is used in
KeyValueSource.fromMap(com.hazelcast.core.IMap) to generate a default
implementation based on a Hazelcast IMap . |
class |
MultiMapKeyValueSource<K,V>
This
KeyValueSource implementation is used in
KeyValueSource.fromMultiMap(com.hazelcast.core.MultiMap) to generate a default
implementation based on a Hazelcast MultiMap . |
class |
SetKeyValueSource<V>
This
KeyValueSource implementation is used in
KeyValueSource.fromSet(com.hazelcast.core.ISet) to generate a default
implementation based on a Hazelcast ISet . |
Modifier and Type | Class and Description |
---|---|
class |
IntermediateChunkNotification<KeyOut,Value>
Notification that is fired every time the chunk limit is reached and is send to the reducers
|
class |
LastChunkNotification<KeyOut,Value>
This notification is used to notify the reducer that this chunk is the last chunk of the
defined partitionId.
|
class |
MapReduceNotification
Base class for all map reduce framework notifications
|
class |
MemberAwareMapReduceNotification
Base class for all notifications based on a member
|
class |
ReducingFinishedNotification
This notification class is used to signal the
JobSupervisor
owner node that a reducer has finished the reducing step for the defined partitionId. |
Modifier and Type | Class and Description |
---|---|
class |
CancelJobSupervisorOperation
This operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes.
|
class |
FireNotificationOperation
This operation is used to transport and execute a notification on a remote node since
the current event service is not capable of reliable transmission so this is a fallback
to sync operations which is hopefully only a temporary workaround!
|
class |
GetResultOperationFactory
This class is used to create
GetResultOperation instances. |
class |
KeysAssignmentOperation
This operation is used to request assignment for keys on the job owners node.
|
class |
KeysAssignmentResult
This class is used to store assignment results in
KeysAssignmentOperation
executions. |
class |
KeyValueJobOperation<K,V>
This operation is used to prepare a
KeyValueSource based
map reduce operation on all cluster members. |
class |
NotifyRemoteExceptionOperation
This operation is used to inform the job owner of a remote exception
|
class |
PostPonePartitionProcessing
This operation is used to tell the job owner to postpone a mapping phase for the defined
partitionId.
|
class |
ProcessingOperation
This is the base class for all map reduce framework operations, it always contains the name of
the JobTracker and the unique jobId
|
class |
ProcessStatsUpdateOperation
This operation is used to update the process statistics on the owner node
|
class |
RequestMemberIdAssignment
This operation is used to do some kind of partitionId based processing on non partition based implementations
of
KeyValueSource (not implementing PartitionIdAware )
which can happen for custom data sources like distributed filesystems that are up to the end user on how to
manage the distribution. |
class |
RequestPartitionMapping
This operation requests a new partition to process by the requester on the job owning node
|
class |
RequestPartitionProcessed
This operation tells the job owner to mark a partition as fully processed
|
class |
RequestPartitionReducing
This operation tells the job owner to start reducing phase of the defined partition on the first
occurrence of a full emitted chunk
|
class |
RequestPartitionResult
This class is used to store the requested result of all kinds of processing operations.
By default it holds a basic result state and maybe the partitionId it was operated otherwise it's value is defined as -1 |
class |
StartProcessingJobOperation<K>
This operation is used to start the actual processing after all node prepared to execute the map reduce job
|
Modifier and Type | Class and Description |
---|---|
class |
MultiMapEventFilter |
class |
MultiMapRecord |
Modifier and Type | Class and Description |
---|---|
class |
ContainsEntryOperation |
class |
CountOperation |
class |
EntrySetOperation |
class |
EntrySetResponse |
class |
GetAllOperation |
class |
KeySetOperation |
class |
MultiMapBackupAwareOperation |
class |
MultiMapKeyBasedOperation |
class |
MultiMapOperation |
class |
MultiMapOperationFactory |
class |
MultiMapReplicationOperation |
class |
MultiMapResponse |
class |
PutBackupOperation |
class |
PutOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
ValuesOperation |
Modifier and Type | Class and Description |
---|---|
class |
MultiMapTransactionLogRecord |
class |
TxnGenerateRecordIdOperation |
class |
TxnLockAndGetOperation |
class |
TxnPutBackupOperation |
class |
TxnPutOperation |
class |
TxnRemoveAllBackupOperation |
class |
TxnRemoveAllOperation |
class |
TxnRemoveBackupOperation |
class |
TxnRemoveOperation |
Modifier and Type | Class and Description |
---|---|
class |
Address
Represents an address of a member in the cluster.
|
Modifier and Type | Method and Description |
---|---|
IdentifiedDataSerializable |
DataSerializableFactory.create(int typeId)
Creates an IdentifiedDataSerializable instance using given type ID
|
Modifier and Type | Method and Description |
---|---|
IdentifiedDataSerializable |
VersionedDataSerializableFactory.create(int typeId,
Version version)
Creates an IdentifiedDataSerializable instance using given type ID and object version
|
Modifier and Type | Class and Description |
---|---|
class |
MultiAttributeProjection<I>
Projection that extracts the values of the given attributes and returns them in an Object[] array.
|
class |
SingleAttributeProjection<I,O>
Projection that extracts the values of the given attribute and returns it.
|
Modifier and Type | Class and Description |
---|---|
class |
PagingPredicate<K,V>
This class is a special Predicate which helps to get a page-by-page result of a query.
|
class |
PartitionPredicate<K,V>
A
Predicate that restricts the execution of a Predicate to a single Partition. |
class |
SqlPredicate
This class contains methods related to conversion of sql query to predicate.
|
class |
TruePredicate<K,V>
A
Predicate which always returns true. |
Modifier and Type | Class and Description |
---|---|
class |
FalsePredicate<K,V>
A
Predicate which always returns false. |
static class |
IndexImpl.NullObject |
class |
IndexInfo |
class |
MapIndexInfo |
Modifier and Type | Class and Description |
---|---|
class |
AbstractIndexAwarePredicate<K,V> |
class |
AbstractPredicate<K,V>
Provides base features for predicates, such as extraction and convertion of the attribute's value.
|
class |
AndPredicate
And Predicate
|
class |
BetweenPredicate
Between Predicate
|
class |
EqualPredicate
Equal Predicate
|
class |
GreaterLessPredicate
Greater Less Predicate
|
class |
ILikePredicate
Ilike Predicate
|
class |
InPredicate
In Predicate
|
class |
InstanceOfPredicate
Predicate version of `instaceof` operator from Java.
|
class |
LikePredicate
Like Predicate
|
class |
NotEqualPredicate
Not Equal Predicate
|
class |
NotPredicate
Not Predicate
|
class |
OrPredicate
Or Predicate
|
class |
RegexPredicate
Regex Predicate
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractReplicatedMapOperation |
class |
AbstractSerializableOperation |
class |
CheckReplicaVersionOperation
Checks whether replica version is in sync with the primary.
|
class |
EvictionOperation
Evicts set of entries from the record store.
|
class |
PutAllOperationFactory
Factory class for
PutAllOperation . |
class |
ReplicateUpdateOperation
Replicates the update happened on the partition owner to the other nodes.
|
class |
ReplicateUpdateToCallerOperation
This operation will update the local record store with the update received from local/remote partition owner.
|
class |
RequestMapDataOperation
Collects and sends the replicated map data from the executing node to the caller via
SyncReplicatedMapDataOperation . |
class |
SyncReplicatedMapDataOperation<K,V>
Carries set of replicated map records for a partition from one node to another
|
class |
VersionResponsePair
Contains response and partition version for update operations on replicated map.
|
Modifier and Type | Class and Description |
---|---|
class |
RecordMigrationInfo |
class |
ReplicatedMapEntryView<K,V> |
Modifier and Type | Class and Description |
---|---|
class |
ReadResultSetImpl<O,E>
A list for the
ReadManyOperation . |
class |
RingbufferContainer<T>
The RingbufferContainer is responsible for creating the actual ring buffer, handling optional ring buffer storage,
keeping the wait/notify key for blocking operations, ring buffer item expiration and other things not related to the
actual ring buffer data structure.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRingBufferOperation
Common logic for all ring buffer operations :
getting the ring buffer container or creating a new one if necessary
serialization/deserialization of ring buffer name
defines the factory ID for the
IdentifiedDataSerializable
|
class |
AddAllBackupOperation
Backup operation for ring buffer
AddAllOperation . |
class |
AddAllOperation
Adds a batch of items to the ring buffer.
|
class |
AddBackupOperation
Backup operation for ring buffer
AddOperation . |
class |
AddOperation
Adds a new ring buffer item.
|
class |
GenericOperation
Ring buffer operations which don't need to send any parameters and which can be determined by only sending the operation
type which is a byte of information.
|
class |
ReadManyOperation<O> |
class |
ReadOneOperation |
class |
ReplicationOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
ScheduledTaskStatistics
Statistics and timing info for a
IScheduledFuture accessible through IScheduledFuture.getStats() |
Modifier and Type | Class and Description |
---|---|
class |
ScheduledTaskHandler
Resource handler pointing to a
IScheduledFuture . |
Modifier and Type | Class and Description |
---|---|
class |
NamedTaskDecorator<V> |
class |
ScheduledRunnableAdapter<V> |
class |
ScheduledTaskDescriptor
Metadata holder for scheduled tasks.
|
class |
ScheduledTaskHandlerImpl |
class |
ScheduledTaskResult |
class |
ScheduledTaskStatisticsImpl |
class |
TaskDefinition<V> |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBackupAwareSchedulerOperation |
class |
AbstractGetAllScheduledOperation |
class |
AbstractSchedulerOperation |
class |
CancelTaskBackupOperation |
class |
CancelTaskOperation |
class |
DisposeBackupTaskOperation |
class |
DisposeTaskOperation |
class |
GetAllScheduledOnMemberOperation |
class |
GetAllScheduledOnPartitionOperation |
class |
GetAllScheduledOnPartitionOperationFactory |
class |
GetDelayOperation |
class |
GetResultOperation<V> |
class |
GetStatisticsOperation |
class |
IsCanceledOperation |
class |
IsDoneOperation |
class |
ResultReadyNotifyOperation<V> |
class |
ScheduleTaskBackupOperation |
class |
ScheduleTaskOperation |
class |
SyncBackupStateOperation |
class |
SyncStateOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
OperationFactory
A Factory for creating
Operation instances. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLocalOperation
Abstract class for local operations, which should not be serializable.
|
class |
DistributedObjectNamespace
Default
ObjectNamespace implementation for DistributedObject . |
class |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedOperation |
class |
BinaryOperationFactory |
class |
SerializableList |
class |
UnmodifiableLazyList<E> |
Modifier and Type | Class and Description |
---|---|
class |
EventEnvelope
An Envelope around an event object.
|
class |
TrueEventFilter
An event filter which does not filter any event and always evaluates
true results. |
Modifier and Type | Class and Description |
---|---|
class |
DeregistrationOperation |
class |
OnJoinRegistrationOperation |
class |
RegistrationOperation |
class |
SendEventOperation
An operation for sending a event to a remote subscriber (not on this node).
|
Modifier and Type | Class and Description |
---|---|
class |
Backup |
class |
PartitionAwareOperationFactory
Creates partition specific operations.
|
class |
PartitionIteratingOperation
Executes Operations on one or more partitions.
|
static class |
PartitionIteratingOperation.PartitionResponse |
Modifier and Type | Class and Description |
---|---|
class |
BackupAckResponse
The {Response} for a
BackupOperation . |
class |
CallTimeoutResponse
An response that indicates that the execution of a single call ran into a timeout.
|
class |
ErrorResponse |
class |
NormalResponse
A NormalResponse is send when an Operation needs to return a value.
|
class |
Response
|
Modifier and Type | Class and Description |
---|---|
class |
DistributedObjectDestroyOperation |
class |
InitializeDistributedObjectOperation |
class |
PostJoinProxyOperation |
Modifier and Type | Class and Description |
---|---|
class |
PublishOperation
ITopic publication operation used when global ordering is enabled
(all nodes listening to the same topic get their messages in the same order).
|
class |
TopicEvent |
Modifier and Type | Class and Description |
---|---|
class |
ReliableTopicMessage
The Object that is going to be stored in the Ringbuffer.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TargetAwareTransactionLogRecord
Represents a change made in a transaction on a specific target Address.
|
interface |
TransactionLogRecord
Represents a change made in a transaction e.g.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractTxOperation |
class |
BroadcastTxRollbackOperation |
class |
CreateAllowedDuringPassiveStateTxBackupLogOperation |
class |
CreateTxBackupLogOperation |
class |
PurgeAllowedDuringPassiveStateTxBackupLogOperation |
class |
PurgeTxBackupLogOperation |
class |
ReplicateAllowedDuringPassiveStateTxBackupLogOperation |
class |
ReplicateTxBackupLogOperation
Replicates the transactionlog to a remote system.
|
class |
RollbackAllowedDuringPassiveStateTxBackupLogOperation |
class |
RollbackTxBackupLogOperation |
Modifier and Type | Class and Description |
---|---|
class |
XATransactionDTO |
Modifier and Type | Class and Description |
---|---|
class |
AbstractXAOperation |
class |
ClearRemoteTransactionBackupOperation |
class |
ClearRemoteTransactionOperation |
class |
CollectRemoteTransactionsOperation |
class |
FinalizeRemoteTransactionBackupOperation |
class |
FinalizeRemoteTransactionOperation |
class |
PutRemoteTransactionBackupOperation |
class |
PutRemoteTransactionOperation |
class |
XaReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
MemberVersion
Determines the Hazelcast codebase version in terms of major.minor.patch version.
|
class |
Version
A generic version to be used with
VersionAware classes. |
Modifier and Type | Class and Description |
---|---|
class |
WanReplicationEvent
Event class used to transmit the actual event object
|
Copyright © 2018 Hazelcast, Inc.. All Rights Reserved.