Package | Description |
---|---|
com.hazelcast.cache.impl.journal | |
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.txnqueue.operations | |
com.hazelcast.concurrent.countdownlatch.operations |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.semaphore.operations |
This package contains the operations on the ISemaphore.
|
com.hazelcast.durableexecutor.impl.operations |
This package contains operations for the DurableExecutorService.
|
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.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 |
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 |
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 |
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 |
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 |
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 |
AddAllBackupOperation
Provides backup functionality for
AddAllOperation |
class |
AddAllOperation
Add collection items to the Queue.
|
class |
CheckAndEvictOperation
Provides eviction functionality for Operations of 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 |
SizeOperation
Notify size of the queue.
|
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 |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
AwaitOperation |
class |
CountDownLatchBackupOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
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 |
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 |
MapEventJournalSubscribeOperation
Performs the initial subscription to the map event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
AddIndexOperation |
class |
AwaitMapFlushOperation
IMap.flush() call waits the end of flush by using this operation. |
class |
BasePutOperation |
class |
BaseRemoveOperation |
class |
ClearBackupOperation |
class |
ClearNearCacheOperation
Deprecated.
|
class |
ClearOperation |
class |
ContainsKeyOperation |
class |
ContainsValueOperation |
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 |
EvictBackupOperation |
class |
EvictBatchBackupOperation
Used to transfer expired keys from owner replica to backup replicas.
|
class |
EvictOperation |
class |
GetAllOperation |
class |
GetEntryViewOperation |
class |
GetOperation |
class |
IsKeyLoadFinishedOperation |
class |
IsPartitionLoadedOperation |
class |
KeyLoadStatusOperation
Notifies RecordStores about completion of loading
|
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 |
MapIsEmptyOperation |
class |
MapOperation |
class |
MapSizeOperation |
class |
MergeOperation |
class |
MultipleEntryBackupOperation |
class |
MultipleEntryOperation |
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 |
PartitionWideEntryWithPredicateBackupOperation |
class |
PartitionWideEntryWithPredicateOperation |
class |
PutAllBackupOperation |
class |
PutAllOperation
Inserts the
MapEntries for a single partition to the local RecordStore . |
class |
PutBackupOperation |
class |
PutFromLoadAllBackupOperation
Runs on backups.
|
class |
PutFromLoadAllOperation
Puts records to map which are loaded from map store by
IMap.loadAll(boolean) |
class |
PutIfAbsentOperation |
class |
PutOperation |
class |
PutTransientOperation |
class |
ReadonlyKeyBasedMapOperation
Abstract
MapOperation that serves as based for readonly operations. |
class |
RemoveBackupOperation |
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 |
RemoveOperation |
class |
ReplaceIfSameOperation |
class |
ReplaceOperation |
class |
SetOperation |
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 |
Modifier and Type | Class and Description |
---|---|
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 |
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 |
TxnLockAndGetOperation
Transactional lock and get operation.
|
class |
TxnPrepareBackupOperation
An operation to prepare transaction by locking the key on key backup owner.
|
class |
TxnPrepareOperation
An operation to prepare transaction by locking the key on the key owner.
|
class |
TxnRollbackBackupOperation
An operation to rollback transaction by unlocking the key on key backup owner.
|
class |
TxnRollbackOperation
An operation to rollback transaction by unlocking the key on key owner.
|
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 |
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 © 2018 Hazelcast, Inc.. All Rights Reserved.