| Modifier and Type | Class and Description | 
|---|---|
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  | 
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key. 
 | 
class  | 
CacheEntryIteratorOperation
Provides iterator functionality for ICache. 
 | 
class  | 
CacheEntryProcessorOperation
Operation of the Cache Entry Processor. 
 | 
class  | 
CacheGetAllOperation
Gets all keys from the cache. 
 | 
class  | 
CacheGetAndRemoveOperation
Cache GetAndRemove Operation. 
 | 
class  | 
CacheGetAndReplaceOperation
Cache GetAndReplace Operation. 
 | 
class  | 
CacheGetConfigOperation
Cache GetConfig Operation. 
 | 
class  | 
CacheGetOperation
Cache Get Operation. 
 | 
class  | 
CacheKeyIteratorOperation
Provides iterator functionality for ICache. 
 | 
class  | 
CacheLoadAllOperation
Loads all entries of the keys to partition record store  
ICacheRecordStore. | 
class  | 
CacheMergeOperation  | 
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  | 
CacheSizeOperation
This operation implementation is for calculating the cluster size of a named cache. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractCardinalityEstimatorOperation  | 
class  | 
AggregateBackupOperation  | 
class  | 
AggregateOperation  | 
class  | 
CardinalityEstimatorBackupAwareOperation  | 
class  | 
EstimateOperation  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CacheAssignAndGetUuidsOperation  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
MapAssignAndGetUuidsOperation  | 
| 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  | 
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  | 
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
Offer operation for the Transactional Queue. 
 | 
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
Reserve offer backup operation for the transactional queue. 
 | 
class  | 
TxnReserveOfferOperation
Reserve offer operation for the transactional queue. 
 | 
class  | 
TxnReservePollBackupOperation
Reserve poll backup operation for the transactional queue. 
 | 
class  | 
TxnReservePollOperation
Reserve poll operation for the transactional queue. 
 | 
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  | 
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  | 
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  | 
DisposeResultBackupOperation  | 
class  | 
DisposeResultOperation  | 
class  | 
RetrieveAndDisposeResultOperation  | 
class  | 
TaskBackupOperation  | 
class  | 
TaskOperation  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CheckReplicaVersion  | 
class  | 
FinalizeMigrationOperation  | 
class  | 
MigrationOperation  | 
class  | 
MigrationRequestOperation  | 
class  | 
ReplicaSyncRequest
The request sent from a replica to the partition owner to synchronize the replica data. 
 | 
class  | 
ReplicaSyncResponse
The replica synchronization response sent from the partition owner to a replica. 
 | 
class  | 
ReplicaSyncRetryResponse
The response to a  
ReplicaSyncRequest that the replica should retry. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
QueryPartitionOperation  | 
| Modifier and Type | Class and Description | 
|---|---|
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  | 
ContainsEntryOperation  | 
class  | 
CountOperation  | 
class  | 
EntrySetOperation  | 
class  | 
GetAllOperation  | 
class  | 
KeySetOperation  | 
class  | 
MultiMapBackupAwareOperation  | 
class  | 
MultiMapKeyBasedOperation  | 
class  | 
MultiMapOperation  | 
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  | 
CheckReplicaVersionOperation
Checks whether replica version is in sync with the primary. 
 | 
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. 
 | 
| 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  | 
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  | 
ReplicationOperation  | 
class  | 
ResultReadyNotifyOperation<V>  | 
class  | 
ScheduleTaskBackupOperation  | 
class  | 
ScheduleTaskOperation  | 
class  | 
ShutdownOperation  | 
class  | 
SyncBackupStateOperation  | 
class  | 
SyncStateOperation  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
BackupAwareOperation
A BackupAwareOperation is an Operation to indicate then when a change is made, a
  
BackupOperation is created to replicate the backup. | 
interface  | 
BackupOperation
When an  
BackupAwareOperation makes a change, the backups need to be replicated to other
 members (depending on the configuration and if change really happened). | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
Backup  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ClearRemoteTransactionBackupOperation  | 
class  | 
ClearRemoteTransactionOperation  | 
class  | 
FinalizeRemoteTransactionBackupOperation  | 
class  | 
FinalizeRemoteTransactionOperation  | 
class  | 
PutRemoteTransactionBackupOperation  | 
class  | 
PutRemoteTransactionOperation  | 
Copyright © 2017 Hazelcast, Inc.. All Rights Reserved.