Package | Description |
---|---|
com.hazelcast.cache.impl.journal | |
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cardinality.impl.operations |
This package contains the operations on the
CardinalityEstimator . |
com.hazelcast.collection.impl.collection.operations | |
com.hazelcast.collection.impl.list.operations | |
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.txncollection.operations | |
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.operations |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.concurrent.semaphore.operations |
This package contains the operations on the ISemaphore.
|
com.hazelcast.crdt.pncounter.operations |
Contains the operations for the
PNCounter member-side
implementation. |
com.hazelcast.durableexecutor.impl.operations |
This package contains operations for the DurableExecutorService.
|
com.hazelcast.executor.impl.operations |
This package contains operations for the IExecutorService.
|
com.hazelcast.map.impl.journal | |
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.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.multimap.impl.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.multimap.impl.txn |
This package contains the Transaction behavior for the Multimap.
|
com.hazelcast.replicatedmap.impl.operation |
This package contains replicated map operations which are executed on remote nodes
|
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.scheduledexecutor.impl.operations | |
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.topic.impl |
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
Modifier and Type | Class and Description |
---|---|
class |
CacheEventJournalSubscribeOperation
Performs the initial subscription to the cache event journal.
|
Modifier and Type | Class and Description |
---|---|
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 |
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key.
|
class |
CacheCreateConfigOperation
Deprecated.
as of 3.10 replaced by
AddCacheConfigOperation , which is used in conjunction with
InvocationUtil.invokeOnStableClusterSerial(NodeEngine,
com.hazelcast.util.function.Supplier, int) to reliably broadcast the CacheConfig to all members of the cluster. |
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 |
CacheExpireBatchBackupOperation
Used to transfer expired keys from owner replica to backup replicas.
|
class |
CacheGetAllOperation
Gets all keys from the cache.
|
class |
CacheGetAndRemoveOperation
Cache GetAndRemove Operation.
|
class |
CacheGetAndReplaceOperation
Cache GetAndReplace Operation.
|
class |
CacheGetConfigOperation
Gets a cache configuration or creates one, if a matching cache config is found in this member's config.
|
class |
CacheGetOperation
Cache Get Operation.
|
class |
CacheKeyIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheLegacyMergeOperation
Contains a merging entry for split-brain healing with a
CacheMergePolicy . |
class |
CacheListenerRegistrationOperation
Listener can be registered and unregistered by
CacheService . |
class |
CacheLoadAllOperation
Loads all entries of the keys to partition record store
ICacheRecordStore . |
class |
CacheManagementConfigOperation
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and
statistics mxbeans of the cache.
|
class |
CacheMergeOperation
Contains multiple merging entries for split-brain healing with a
SplitBrainMergePolicy . |
class |
CacheOperation
Base Cache Operation.
|
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 |
CacheRemoveBackupOperation
Backup operation used by remove operations.
|
class |
CacheRemoveOperation
Operation implementation for cache remove functionality.
|
class |
CacheReplaceOperation
Operator implementation for cache replace functionality.
|
class |
CacheSetExpiryPolicyBackupOperation |
class |
CacheSetExpiryPolicyOperation |
class |
CacheSizeOperation
This operation implementation is for calculating the cluster size of a named cache.
|
class |
KeyBasedCacheOperation
Operations running on a single key should extend this class.
|
class |
MutatingCacheOperation
Base class for all mutable cache operations.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCardinalityEstimatorOperation |
class |
AggregateBackupOperation |
class |
AggregateOperation |
class |
CardinalityEstimatorBackupAwareOperation |
class |
EstimateOperation |
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 |
CollectionMergeBackupOperation
Creates backups for merged collection items after split-brain healing with a
SplitBrainMergePolicy . |
class |
CollectionMergeOperation
Merges a
SplitBrainMergeTypes.CollectionMergeTypes for split-brain healing with a SplitBrainMergePolicy . |
class |
CollectionOperation |
class |
CollectionRemoveBackupOperation |
class |
CollectionRemoveOperation |
class |
CollectionSizeOperation |
Modifier and Type | Class and Description |
---|---|
class |
ListAddAllOperation |
class |
ListAddOperation |
class |
ListGetOperation |
class |
ListIndexOfOperation |
class |
ListRemoveOperation |
class |
ListSetBackupOperation |
class |
ListSetOperation |
class |
ListSubOperation |
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 |
QueueMergeBackupOperation
Creates backups for merged queue items after split-brain healing with a
SplitBrainMergePolicy . |
class |
QueueMergeOperation
Merges a
SplitBrainMergeTypes.QueueMergeTypes for split-brain healing with a SplitBrainMergePolicy . |
class |
QueueOperation
This class contains methods for Queue operations
such as
AddAllOperation . |
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 |
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 |
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 |
GetAndAddOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAlterOperation |
class |
AbstractAtomicReferenceOperation |
class |
AlterAndGetOperation |
class |
AlterOperation |
class |
ApplyOperation |
class |
AtomicReferenceBackupAwareOperation |
class |
CompareAndSetOperation |
class |
GetAndAlterOperation |
class |
GetAndSetOperation |
class |
IsNullOperation |
class |
SetAndGetOperation |
class |
SetBackupOperation |
Modifier and Type | Class and Description |
---|---|
class |
AwaitOperation |
class |
CountDownLatchBackupOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLockOperation |
class |
AwaitBackupOperation |
class |
BeforeAwaitBackupOperation |
class |
BeforeAwaitOperation |
class |
GetLockCountOperation |
class |
GetRemainingLeaseTimeOperation |
class |
IsLockedOperation |
class |
LocalLockCleanupOperation
Locally executed operation which unlocks a lock if it is held by a
specific owner.
|
class |
LockBackupOperation |
class |
LockOperation |
class |
SignalBackupOperation |
class |
SignalOperation |
class |
UnlockBackupOperation |
class |
UnlockIfLeaseExpiredOperation |
class |
UnlockOperation |
Modifier and Type | Class and Description |
---|---|
class |
AcquireBackupOperation |
class |
AcquireOperation |
class |
AvailableOperation |
class |
IncreaseBackupOperation |
class |
IncreaseOperation |
class |
InitBackupOperation |
class |
InitOperation |
class |
ReduceBackupOperation |
class |
ReduceOperation |
class |
ReleaseBackupOperation |
class |
ReleaseOperation |
class |
SemaphoreBackupAwareOperation |
class |
SemaphoreBackupOperation |
class |
SemaphoreDetachMemberBackupOperation |
class |
SemaphoreDetachMemberOperation |
class |
SemaphoreOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPNCounterOperation
Base class for
PNCounter query and
mutation operation implementations. |
class |
AddOperation
Addition/subtraction operation for a
PNCounter . |
class |
GetOperation
Query operation to retrieve the current value of the
PNCounter . |
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 |
CallableTaskOperation |
class |
CancellationOperation |
class |
MemberCallableTaskOperation |
Modifier and Type | Class and Description |
---|---|
class |
MapEventJournalSubscribeOperation
Performs the initial subscription to the map event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
AddIndexOperation |
class |
AddInterceptorOperation |
class |
AwaitMapFlushOperation
IMap.flush() call waits the end of flush by using this operation. |
class |
BasePutOperation |
class |
BaseRemoveOperation |
class |
ClearNearCacheOperation
Deprecated.
|
class |
ContainsKeyOperation |
class |
ContainsValueOperation |
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 |
EvictBackupOperation |
class |
EvictBatchBackupOperation
Used to transfer expired keys from owner replica to backup replicas.
|
class |
EvictOperation |
class |
GetEntryViewOperation |
class |
IsKeyLoadFinishedOperation
Returns if the key loading and dispatching has finished on this partition
|
class |
IsPartitionLoadedOperation |
class |
KeyBasedMapOperation |
class |
KeyLoadStatusOperation
Notifies record store about completion of key loading.
|
class |
LegacyMergeOperation
Contains a merging entry for split-brain healing with a
MapMergePolicy . |
class |
LoadAllOperation
Triggers loading values for the given keys from the defined
MapLoader . |
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 |
MapIsEmptyOperation |
class |
MapOperation |
class |
MapSizeOperation |
class |
MultipleEntryBackupOperation |
class |
MultipleEntryOperation |
class |
MultipleEntryWithPredicateBackupOperation |
class |
MultipleEntryWithPredicateOperation |
class |
NotifyMapFlushOperation
|
class |
PartitionWideEntryBackupOperation |
class |
PartitionWideEntryOperation
GOTCHA: This operation does NOT load missing keys from map-store for now.
|
class |
PartitionWideEntryWithPredicateBackupOperation |
class |
PartitionWideEntryWithPredicateOperation |
class |
PutAllBackupOperation |
class |
PutAllOperation
Inserts the
MapEntries for a single partition to the local RecordStore . |
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 |
SetTtlBackupOperation |
class |
SetTtlOperation |
class |
TriggerLoadIfNeededOperation
Triggers key loading on member with
MapKeyLoader.Role.SENDER
or MapKeyLoader.Role.SENDER_BACKUP key
loader role if keys have not yet been loaded. |
class |
TryPutOperation |
class |
TryRemoveOperation |
Modifier and Type | Class and Description |
---|---|
class |
QueryOperation |
class |
QueryPartitionOperation |
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 |
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 |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractBackupAwareMultiMapOperation |
class |
AbstractKeyBasedMultiMapOperation |
class |
AbstractMultiMapOperation |
class |
ContainsEntryOperation |
class |
CountOperation |
class |
DeleteBackupOperation |
class |
DeleteOperation |
class |
EntrySetOperation |
class |
GetAllOperation |
class |
KeySetOperation |
class |
PutBackupOperation |
class |
PutOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
ValuesOperation |
Modifier and Type | Class and Description |
---|---|
class |
TxnGenerateRecordIdOperation |
class |
TxnLockAndGetOperation |
class |
TxnPutBackupOperation |
class |
TxnPutOperation |
class |
TxnRemoveAllBackupOperation |
class |
TxnRemoveAllOperation |
class |
TxnRemoveBackupOperation |
class |
TxnRemoveOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedSerializableOperation |
class |
AbstractReplicatedMapOperation |
class |
EvictionOperation
Evicts set of entries from the record store.
|
class |
ReplicateUpdateOperation
Replicates the update happened on the partition owner to the other nodes.
|
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 |
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 |
MergeBackupOperation
Contains the entire ringbuffer as a result of split-brain healing with a
SplitBrainMergePolicy . |
class |
ReadManyOperation<O> |
class |
ReadOneOperation |
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 |
GetDelayOperation |
class |
GetResultOperation<V> |
class |
GetStatisticsOperation |
class |
IsCanceledOperation |
class |
IsDoneOperation |
class |
MergeOperation |
class |
ReplicationOperation |
class |
ResultReadyNotifyOperation<V> |
class |
ScheduleTaskBackupOperation |
class |
ScheduleTaskOperation |
class |
SyncBackupStateOperation |
class |
SyncStateOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedOperation |
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).
|
Copyright © 2019 Hazelcast, Inc.. All Rights Reserved.