Package | Description |
---|---|
com.hazelcast.cache.impl |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cache.impl.eviction | |
com.hazelcast.cache.impl.journal | |
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.cardinality.impl | |
com.hazelcast.cardinality.impl.operations |
This package contains the operations on the
CardinalityEstimator . |
com.hazelcast.client.impl |
Implementation classes of the com.hazelcast.client interfaces
|
com.hazelcast.client.impl.operations |
Contains client operations
|
com.hazelcast.client.impl.protocol.task |
Client tasks associated with requests.
|
com.hazelcast.client.impl.protocol.task.atomiclong |
Client protocol tasks implementations for AtomicLong
|
com.hazelcast.client.impl.protocol.task.atomicreference |
Client protocol tasks implementations for AtomicReference
|
com.hazelcast.client.impl.protocol.task.cache |
Client protocol tasks implementations for JCache
|
com.hazelcast.client.impl.protocol.task.cardinality | |
com.hazelcast.client.impl.protocol.task.condition |
Client protocol tasks implementations for Condition
|
com.hazelcast.client.impl.protocol.task.countdownlatch |
Client protocol tasks implementations for CountDownLatch
|
com.hazelcast.client.impl.protocol.task.crdt.pncounter | |
com.hazelcast.client.impl.protocol.task.executorservice |
Client protocol tasks implementations for ExecutorService
|
com.hazelcast.client.impl.protocol.task.executorservice.durable | |
com.hazelcast.client.impl.protocol.task.list |
Client protocol tasks implementations for List
|
com.hazelcast.client.impl.protocol.task.lock |
Client protocol tasks implementations for ILock
|
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
com.hazelcast.client.impl.protocol.task.multimap |
Client protocol tasks implementations for multi map
|
com.hazelcast.client.impl.protocol.task.queue |
Client protocol tasks implementations for Queue
|
com.hazelcast.client.impl.protocol.task.replicatedmap |
Client protocol tasks implementations for ReplicatedMap
|
com.hazelcast.client.impl.protocol.task.ringbuffer |
Client protocol tasks implementations for Ringbuffer
|
com.hazelcast.client.impl.protocol.task.scheduledexecutor | |
com.hazelcast.client.impl.protocol.task.semaphore |
Client protocol tasks implementations for Semaphore
|
com.hazelcast.client.impl.protocol.task.set |
Client protocol tasks implementations for set
|
com.hazelcast.client.impl.protocol.task.topic |
Client protocol tasks implementations for Topic
|
com.hazelcast.client.impl.protocol.task.transaction |
Client protocol tasks implementations for Transaction related
|
com.hazelcast.client.impl.querycache.subscriber |
Contains Hazelcast Enterprise version client-side query cache
subscriber implementation classes.
|
com.hazelcast.collection.impl | |
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 |
This package contains IAtomicLong functionality for Hazelcast.
The IAtomicLong is the distributed version of the AtomicLong . |
com.hazelcast.concurrent.atomiclong.operations |
This package contains the operations on the IAtomicLong.
|
com.hazelcast.concurrent.atomicreference |
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference . |
com.hazelcast.concurrent.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
com.hazelcast.concurrent.countdownlatch |
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch . |
com.hazelcast.concurrent.countdownlatch.operations |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.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.crdt |
This package contains CRDT (conflict-free replicated data type)
implementations based on the Hazelcast infrastructure.
|
com.hazelcast.crdt.pncounter |
This package contains the PN (Positive-Negative) CRDT counter
implementation.
|
com.hazelcast.crdt.pncounter.operations |
Contains the operations for the
PNCounter member-side
implementation. |
com.hazelcast.durableexecutor.impl |
Contains the
DurableExecutorService implementation classes. |
com.hazelcast.durableexecutor.impl.operations |
This package contains operations for the DurableExecutorService.
|
com.hazelcast.executor.impl |
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the ExecutorService and provides all kinds
of additional methods related to distributed systems. |
com.hazelcast.executor.impl.operations |
This package contains operations for the IExecutorService.
|
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.internal.diagnostics |
Contains functionality what is happening in a HazelcastInstance.
|
com.hazelcast.internal.dynamicconfig |
Classes related to Dynamic Configuration.
|
com.hazelcast.internal.eviction |
Eviction policy implementations.
|
com.hazelcast.internal.journal |
This package contains supporting classes for data structure specific event journals.
|
com.hazelcast.internal.management |
Contains classes to provide data/operation interface for Management Center.
|
com.hazelcast.internal.management.operation |
Contains operations that are called from Management Center.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.internal.partition.operation |
Contains the operations for partition package.
|
com.hazelcast.internal.usercodedeployment.impl.operation | |
com.hazelcast.internal.util |
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
|
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.eviction |
This package contains eviction classes.
|
com.hazelcast.map.impl.journal | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.proxy |
Contains map proxy implementation and support classes.
|
com.hazelcast.map.impl.query | |
com.hazelcast.map.impl.querycache |
Contains query cache internal implementation classes.
|
com.hazelcast.map.impl.querycache.subscriber.operation |
This package contains Enterprise specific operations for
QueryCache . |
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
com.hazelcast.mapreduce.impl |
This package contains the default implementation for the map reduce framework
internals.
|
com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
com.hazelcast.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.quorum.impl |
Contains cluster quorum implementation classes.
|
com.hazelcast.replicatedmap.impl |
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally.
|
com.hazelcast.replicatedmap.impl.operation |
This package contains replicated map operations which are executed on remote nodes
|
com.hazelcast.ringbuffer.impl |
Contains the
Ringbuffer implementation classes. |
com.hazelcast.ringbuffer.impl.operations | |
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.merge |
This package contains split-brain related classes.
|
com.hazelcast.spi.impl.operationexecutor |
Contains the
OperationRunner code. |
com.hazelcast.spi.impl.operationexecutor.impl |
Contains the
OperationExecutorImpl code. |
com.hazelcast.spi.impl.operationservice |
Contains the
InternalOperationService API. |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.spi.impl.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.spi.impl.operationutil |
Contains utiliy classes related to
Operation |
com.hazelcast.spi.impl.proxyservice.impl |
Contains the implementation of the
InternalProxyService . |
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.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 |
Modifier and Type | Method and Description |
---|---|
Operation |
CacheOperationProvider.createContainsKeyOperation(Data key) |
Operation |
DefaultOperationProvider.createContainsKeyOperation(Data key) |
Operation |
CacheOperationProvider.createEntryIteratorOperation(int lastTableIndex,
int fetchSize) |
Operation |
DefaultOperationProvider.createEntryIteratorOperation(int lastTableIndex,
int fetchSize) |
Operation |
CacheOperationProvider.createEntryProcessorOperation(Data key,
Integer completionId,
javax.cache.processor.EntryProcessor entryProcessor,
Object... args) |
Operation |
DefaultOperationProvider.createEntryProcessorOperation(Data key,
Integer completionId,
javax.cache.processor.EntryProcessor entryProcessor,
Object... arguments) |
Operation |
CacheOperationProvider.createGetAndRemoveOperation(Data key,
int completionId) |
Operation |
DefaultOperationProvider.createGetAndRemoveOperation(Data key,
int completionId) |
Operation |
CacheOperationProvider.createGetAndReplaceOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createGetAndReplaceOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createGetOperation(Data key,
javax.cache.expiry.ExpiryPolicy policy) |
Operation |
DefaultOperationProvider.createGetOperation(Data key,
javax.cache.expiry.ExpiryPolicy policy) |
Operation |
CacheOperationProvider.createKeyIteratorOperation(int lastTableIndex,
int fetchSize) |
Operation |
DefaultOperationProvider.createKeyIteratorOperation(int lastTableIndex,
int fetchSize) |
Operation |
CacheOperationProvider.createMergeOperation(String name,
List<SplitBrainMergeTypes.CacheMergeTypes> mergingEntries,
SplitBrainMergePolicy<Data,SplitBrainMergeTypes.CacheMergeTypes> policy) |
Operation |
DefaultOperationProvider.createMergeOperation(String name,
List<SplitBrainMergeTypes.CacheMergeTypes> mergingEntries,
SplitBrainMergePolicy<Data,SplitBrainMergeTypes.CacheMergeTypes> policy) |
Operation |
CacheOperationProvider.createPutAllOperation(List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createPutAllOperation(List<Map.Entry<Data,Data>> entries,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createPutIfAbsentOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createPutIfAbsentOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createPutOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
boolean get,
int completionId) |
Operation |
DefaultOperationProvider.createPutOperation(Data key,
Data value,
javax.cache.expiry.ExpiryPolicy policy,
boolean get,
int completionId) |
Operation |
CacheOperationProvider.createRemoveOperation(Data key,
Data value,
int completionId) |
Operation |
DefaultOperationProvider.createRemoveOperation(Data key,
Data oldValue,
int completionId) |
Operation |
CacheOperationProvider.createReplaceOperation(Data key,
Data oldValue,
Data newValue,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
DefaultOperationProvider.createReplaceOperation(Data key,
Data oldValue,
Data newValue,
javax.cache.expiry.ExpiryPolicy policy,
int completionId) |
Operation |
CacheOperationProvider.createSetExpiryPolicyOperation(List<Data> keys,
Data expiryPolicy) |
Operation |
DefaultOperationProvider.createSetExpiryPolicyOperation(List<Data> keys,
Data expiryPolicy) |
Operation |
AbstractCacheService.getPreJoinOperation() |
Operation |
CacheService.prepareReplicationOperation(PartitionReplicationEvent event) |
Operation |
CacheService.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
CacheClearExpiredRecordsTask.newBackupExpiryOp(ICacheRecordStore store,
Collection<ExpiredKey> expiredKeys) |
protected Operation |
CacheClearExpiredRecordsTask.newPrimaryExpiryOp(int expirationPercentage,
CachePartitionSegment container) |
Modifier and Type | Class and Description |
---|---|
class |
CacheEventJournalReadOperation<K,V,T>
Reads from the cache event journal in batches.
|
class |
CacheEventJournalSubscribeOperation
Performs the initial subscription to the cache event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
AddCacheConfigOperation |
class |
CacheBackupEntryProcessorOperation
Operation of the Cache Backup Entry Processor.
|
class |
CacheClearBackupOperation
Backup operation of
CacheClearOperation . |
class |
CacheClearExpiredOperation |
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 |
CacheGetInvalidationMetaDataOperation |
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 |
CacheReplicationOperation
Replication operation is the data migration operation of
CacheRecordStore . |
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.
|
class |
OnJoinCacheOperation
Operation executed on joining members so they become aware of
CacheConfig s dynamically created via
CacheManager.createCache(String, Configuration) . |
Modifier and Type | Method and Description |
---|---|
Operation |
CacheClearOperationFactory.createOperation() |
Operation |
CacheGetAllOperationFactory.createOperation() |
Operation |
CacheSizeOperationFactory.createOperation() |
Operation |
CacheRemoveAllOperationFactory.createOperation() |
Operation |
CacheLoadAllOperationFactory.createOperation() |
Operation |
CacheMergeOperationFactory.createPartitionOperation(int partitionId) |
Operation |
CachePutAllOperation.getBackupOperation() |
Operation |
CacheGetAndRemoveOperation.getBackupOperation() |
Operation |
CacheLoadAllOperation.getBackupOperation() |
Operation |
CacheClearOperation.getBackupOperation() |
Operation |
CacheLegacyMergeOperation.getBackupOperation() |
Operation |
CacheRemoveAllOperation.getBackupOperation() |
Operation |
CachePutOperation.getBackupOperation() |
Operation |
CacheSetExpiryPolicyOperation.getBackupOperation() |
Operation |
CacheReplaceOperation.getBackupOperation() |
Operation |
CacheRemoveOperation.getBackupOperation() |
Operation |
CacheEntryProcessorOperation.getBackupOperation() |
Operation |
CacheGetAndReplaceOperation.getBackupOperation() |
Operation |
CachePutIfAbsentOperation.getBackupOperation() |
Operation |
CacheMergeOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
CardinalityEstimatorService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCardinalityEstimatorOperation |
class |
AggregateBackupOperation |
class |
AggregateOperation |
class |
CardinalityEstimatorBackupAwareOperation |
class |
EstimateOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
AggregateOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
AddInterceptorOperationSupplier.get() |
Operation |
CollectRemoteTransactionsOperationSupplier.get() |
Operation |
ReAuthenticationOperationSupplier.get() |
Operation |
RemoveInterceptorOperationSupplier.get() |
Operation |
ClientEngineImpl.getPreJoinOperation() |
Modifier and Type | Class and Description |
---|---|
class |
AbstractClientOperation |
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
GetConnectedClientsOperation |
class |
OnJoinClientOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
OperationFactoryWrapper.createOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
CreateProxiesMessageTask.get() |
Operation |
DeployClassesMessageTask.get() |
protected abstract Operation |
AbstractPartitionMessageTask.prepareOperation() |
protected abstract Operation |
AbstractAddressMessageTask.prepareOperation() |
protected abstract Operation |
AbstractInvocationMessageTask.prepareOperation() |
protected Operation |
CreateProxyMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected abstract Supplier<Operation> |
AbstractMultiTargetMessageTask.createOperationSupplier() |
protected Supplier<Operation> |
CreateProxiesMessageTask.createOperationSupplier() |
protected Supplier<Operation> |
AuthenticationBaseMessageTask.createOperationSupplier() |
protected Supplier<Operation> |
DeployClassesMessageTask.createOperationSupplier() |
Modifier and Type | Method and Description |
---|---|
protected abstract InvocationBuilder |
AbstractInvocationMessageTask.getInvocationBuilder(Operation op) |
protected InvocationBuilder |
CreateProxyMessageTask.getInvocationBuilder(Operation op) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
AtomicLongGetAndSetMessageTask.prepareOperation() |
protected Operation |
AtomicLongAlterAndGetMessageTask.prepareOperation() |
protected Operation |
AtomicLongGetAndAddMessageTask.prepareOperation() |
protected Operation |
AtomicLongDecrementAndGetMessageTask.prepareOperation() |
protected Operation |
AtomicLongApplyMessageTask.prepareOperation() |
protected Operation |
AtomicLongAlterMessageTask.prepareOperation() |
protected Operation |
AtomicLongAddAndGetMessageTask.prepareOperation() |
protected Operation |
AtomicLongCompareAndSetMessageTask.prepareOperation() |
protected Operation |
AtomicLongGetAndIncrementMessageTask.prepareOperation() |
protected Operation |
AtomicLongGetMessageTask.prepareOperation() |
protected Operation |
AtomicLongGetAndAlterMessageTask.prepareOperation() |
protected Operation |
AtomicLongIncrementAndGetMessageTask.prepareOperation() |
protected Operation |
AtomicLongSetMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
AtomicReferenceCompareAndSetMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceAlterAndGetMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceContainsMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceGetAndAlterMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceSetAndGetMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceGetAndSetMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceGetMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceIsNullMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceAlterMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceSetMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceApplyMessageTask.prepareOperation() |
protected Operation |
AtomicReferenceClearMessageTask.prepareOperation() |
Modifier and Type | Class and Description |
---|---|
class |
CacheAssignAndGetUuidsOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
CacheAssignAndGetUuidsOperationFactory.createOperation() |
protected Operation |
CacheEventJournalSubscribeTask.prepareOperation() |
protected Operation |
CacheIterateMessageTask.prepareOperation() |
protected Operation |
CacheSetExpiryPolicyMessageTask.prepareOperation() |
protected Operation |
CacheGetMessageTask.prepareOperation() |
protected Operation |
CacheListenerRegistrationMessageTask.prepareOperation() |
protected Operation |
CacheEntryProcessorMessageTask.prepareOperation() |
protected Operation |
CachePutIfAbsentMessageTask.prepareOperation() |
protected Operation |
CacheGetAndReplaceMessageTask.prepareOperation() |
protected Operation |
CachePutMessageTask.prepareOperation() |
protected Operation |
CachePutAllMessageTask.prepareOperation() |
protected Operation |
CacheRemoveMessageTask.prepareOperation() |
protected Operation |
CacheReplaceMessageTask.prepareOperation() |
protected Operation |
CacheContainsKeyMessageTask.prepareOperation() |
protected Operation |
CacheEventJournalReadTask.prepareOperation() |
protected Operation |
CacheGetConfigMessageTask.prepareOperation() |
protected Operation |
CacheGetAndRemoveMessageTask.prepareOperation() |
protected Operation |
CacheManagementConfigMessageTask.prepareOperation() |
protected Operation |
CacheFetchNearCacheInvalidationMetadataTask.prepareOperation() |
protected Operation |
CacheIterateEntriesMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
CacheListenerRegistrationMessageTask.getInvocationBuilder(Operation op) |
protected InvocationBuilder |
CacheManagementConfigMessageTask.getInvocationBuilder(Operation op) |
protected InvocationBuilder |
CacheFetchNearCacheInvalidationMetadataTask.getInvocationBuilder(Operation op) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
CardinalityEstimatorEstimateMessageTask.prepareOperation() |
protected Operation |
CardinalityEstimatorAddMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
ConditionSignalAllMessageTask.prepareOperation() |
protected Operation |
ConditionBeforeAwaitMessageTask.prepareOperation() |
protected Operation |
ConditionSignalMessageTask.prepareOperation() |
protected Operation |
ConditionAwaitMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
CountDownLatchGetCountMessageTask.prepareOperation() |
protected Operation |
CountDownLatchAwaitMessageTask.prepareOperation() |
protected Operation |
CountDownLatchCountDownMessageTask.prepareOperation() |
protected Operation |
CountDownLatchTrySetCountMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
PNCounterGetMessageTask.prepareOperation() |
protected Operation |
PNCounterAddMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
ExecutorServiceSubmitToPartitionMessageTask.prepareOperation() |
protected Operation |
ExecutorServiceSubmitToAddressMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
ExecutorServiceSubmitToPartitionMessageTask.getInvocationBuilder(Operation op) |
protected InvocationBuilder |
ExecutorServiceSubmitToAddressMessageTask.getInvocationBuilder(Operation op) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
DurableExecutorRetrieveAndDisposeResultMessageTask.prepareOperation() |
protected Operation |
DurableExecutorRetrieveResultMessageTask.prepareOperation() |
protected Operation |
DurableExecutorSubmitToPartitionMessageTask.prepareOperation() |
protected Operation |
DurableExecutorDisposeResultMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
ListIteratorMessageTask.prepareOperation() |
protected Operation |
ListIndexOfMessageTask.prepareOperation() |
protected Operation |
ListGetMessageTask.prepareOperation() |
protected Operation |
ListLastIndexOfMessageTask.prepareOperation() |
protected Operation |
ListAddMessageTask.prepareOperation() |
protected Operation |
ListRemoveMessageTask.prepareOperation() |
protected Operation |
ListListIteratorMessageTask.prepareOperation() |
protected Operation |
ListCompareAndRetainAllMessageTask.prepareOperation() |
protected Operation |
ListIsEmptyMessageTask.prepareOperation() |
protected Operation |
ListCompareAndRemoveAllMessageTask.prepareOperation() |
protected Operation |
ListSizeMessageTask.prepareOperation() |
protected Operation |
ListContainsMessageTask.prepareOperation() |
protected Operation |
ListAddWithIndexMessageTask.prepareOperation() |
protected Operation |
ListSubMessageTask.prepareOperation() |
protected Operation |
ListGetAllMessageTask.prepareOperation() |
protected Operation |
ListRemoveWithIndexMessageTask.prepareOperation() |
protected Operation |
ListAddAllMessageTask.prepareOperation() |
protected Operation |
ListContainsAllMessageTask.prepareOperation() |
protected Operation |
ListAddAllWithIndexMessageTask.prepareOperation() |
protected Operation |
ListSetMessageTask.prepareOperation() |
protected Operation |
ListClearMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
LockIsLockedMessageTask.prepareOperation() |
protected Operation |
LockGetRemainingLeaseTimeMessageTask.prepareOperation() |
protected Operation |
LockForceUnlockMessageTask.prepareOperation() |
protected Operation |
LockIsLockedByCurrentThreadMessageTask.prepareOperation() |
protected Operation |
LockLockMessageTask.prepareOperation() |
protected Operation |
LockUnlockMessageTask.prepareOperation() |
protected Operation |
LockTryLockMessageTask.prepareOperation() |
protected Operation |
LockGetLockCountMessageTask.prepareOperation() |
Modifier and Type | Class and Description |
---|---|
class |
MapAssignAndGetUuidsOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
MapAssignAndGetUuidsOperationFactory.createOperation() |
protected Operation |
MapPutAllMessageTask.prepareOperation() |
protected Operation |
MapGetMessageTask.prepareOperation() |
protected Operation |
MapFetchNearCacheInvalidationMetadataTask.prepareOperation() |
protected Operation |
MapReplaceMessageTask.prepareOperation() |
protected Operation |
MapClearNearCacheMessageTask.prepareOperation()
Deprecated.
|
protected Operation |
MapFetchWithQueryMessageTask.prepareOperation() |
protected Operation |
MapGetAllMessageTask.prepareOperation() |
protected Operation |
MapTryLockMessageTask.prepareOperation() |
protected Operation |
MapIsLockedMessageTask.prepareOperation() |
protected Operation |
MapDeleteMessageTask.prepareOperation() |
protected Operation |
MapPutTransientWithMaxIdleMessageTask.prepareOperation() |
protected Operation |
MapLockMessageTask.prepareOperation() |
protected Operation |
MapUnlockMessageTask.prepareOperation() |
protected Operation |
MapPutTransientMessageTask.prepareOperation() |
protected Operation |
MapForceUnlockMessageTask.prepareOperation() |
protected Operation |
MapEventJournalReadTask.prepareOperation() |
protected Operation |
MapGetEntryViewMessageTask.prepareOperation() |
protected Operation |
MapSetMessageTask.prepareOperation() |
protected Operation |
MapFetchKeysMessageTask.prepareOperation() |
protected Operation |
MapSetTtlMessageTask.prepareOperation() |
protected Operation |
MapSetWithMaxIdleMessageTask.prepareOperation() |
protected Operation |
MapContainsKeyMessageTask.prepareOperation() |
protected Operation |
MapPutIfAbsentMessageTask.prepareOperation() |
protected Operation |
MapEventJournalSubscribeTask.prepareOperation() |
protected Operation |
MapPutWithMaxIdleMessageTask.prepareOperation() |
protected Operation |
MapPutMessageTask.prepareOperation() |
protected Operation |
MapSubmitToKeyMessageTask.prepareOperation() |
protected Operation |
MapExecuteOnKeyMessageTask.prepareOperation() |
protected Operation |
MapSetReadCursorMessageTask.prepareOperation() |
protected Operation |
MapFetchEntriesMessageTask.prepareOperation() |
protected Operation |
MapPutIfAbsentWithMaxIdleMessageTask.prepareOperation() |
protected Operation |
MapReplaceIfSameMessageTask.prepareOperation() |
protected Operation |
MapTryPutMessageTask.prepareOperation() |
protected Operation |
MapTryRemoveMessageTask.prepareOperation() |
protected Operation |
MapRemoveIfSameMessageTask.prepareOperation() |
protected Operation |
MapRemoveMessageTask.prepareOperation() |
protected Operation |
MapEvictMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Supplier<Operation> |
MapAddInterceptorMessageTask.createOperationSupplier() |
protected Supplier<Operation> |
MapRemoveInterceptorMessageTask.createOperationSupplier() |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
MapFetchNearCacheInvalidationMetadataTask.getInvocationBuilder(Operation op) |
protected InvocationBuilder |
MapClearNearCacheMessageTask.getInvocationBuilder(Operation op)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected Operation |
MultiMapDeleteMessageTask.prepareOperation() |
protected Operation |
MultiMapForceUnlockMessageTask.prepareOperation() |
protected Operation |
MultiMapRemoveMessageTask.prepareOperation() |
protected Operation |
MultiMapValueCountMessageTask.prepareOperation() |
protected Operation |
MultiMapUnlockMessageTask.prepareOperation() |
protected Operation |
MultiMapContainsKeyMessageTask.prepareOperation() |
protected Operation |
MultiMapGetMessageTask.prepareOperation() |
protected Operation |
MultiMapIsLockedMessageTask.prepareOperation() |
protected Operation |
MultiMapContainsEntryMessageTask.prepareOperation() |
protected Operation |
MultiMapTryLockMessageTask.prepareOperation() |
protected Operation |
MultiMapLockMessageTask.prepareOperation() |
protected Operation |
MultiMapPutMessageTask.prepareOperation() |
protected Operation |
MultiMapRemoveEntryMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
QueuePeekMessageTask.prepareOperation() |
protected Operation |
QueueSizeMessageTask.prepareOperation() |
protected Operation |
QueueOfferMessageTask.prepareOperation() |
protected Operation |
QueueDrainMaxSizeMessageTask.prepareOperation() |
protected Operation |
QueueIteratorMessageTask.prepareOperation() |
protected Operation |
QueueRemainingCapacityMessageTask.prepareOperation() |
protected Operation |
QueueIsEmptyMessageTask.prepareOperation() |
protected Operation |
QueueContainsMessageTask.prepareOperation() |
protected Operation |
QueuePutMessageTask.prepareOperation() |
protected Operation |
QueueRemoveMessageTask.prepareOperation() |
protected Operation |
QueueCompareAndRemoveAllMessageTask.prepareOperation() |
protected Operation |
QueueAddAllMessageTask.prepareOperation() |
protected Operation |
QueueCompareAndRetainAllMessageTask.prepareOperation() |
protected Operation |
QueueContainsAllMessageTask.prepareOperation() |
protected Operation |
QueueTakeMessageTask.prepareOperation() |
protected Operation |
QueueClearMessageTask.prepareOperation() |
protected Operation |
QueuePollMessageTask.prepareOperation() |
protected Operation |
QueueDrainMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
ReplicatedMapPutMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapSizeMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapValuesMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapGetMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapEntrySetMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapIsEmptyMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapKeySetMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapRemoveMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapContainsValueMessageTask.prepareOperation() |
protected Operation |
ReplicatedMapContainsKeyMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
RingbufferTailSequenceMessageTask.prepareOperation() |
protected Operation |
RingbufferReadOneMessageTask.prepareOperation() |
protected Operation |
RingbufferHeadSequenceMessageTask.prepareOperation() |
protected Operation |
RingbufferRemainingCapacityMessageTask.prepareOperation() |
protected Operation |
RingbufferAddMessageTask.prepareOperation() |
protected Operation |
RingbufferAddAllMessageTask.prepareOperation() |
protected Operation |
RingbufferReadManyMessageTask.prepareOperation() |
protected Operation |
RingbufferSizeMessageTask.prepareOperation() |
protected Operation |
RingbufferCapacityMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
ScheduledExecutorTaskIsDoneFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskDisposeFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorSubmitToAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskIsDoneFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskGetDelayFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskGetResultFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskGetDelayFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskCancelFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskGetResultFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorShutdownMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskGetStatisticsFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskIsCancelledFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskGetStatisticsFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskCancelFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskDisposeFromPartitionMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorTaskIsCancelledFromAddressMessageTask.prepareOperation() |
protected Operation |
ScheduledExecutorSubmitToPartitionMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
ScheduledExecutorShutdownMessageTask.getInvocationBuilder(Operation op) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
SemaphoreReleaseMessageTask.prepareOperation() |
protected Operation |
SemaphoreIncreasePermitsMessageTask.prepareOperation() |
protected Operation |
SemaphoreAcquireMessageTask.prepareOperation() |
protected Operation |
SemaphoreReducePermitsMessageTask.prepareOperation() |
protected Operation |
SemaphoreAvailablePermitsMessageTasks.prepareOperation() |
protected Operation |
SemaphoreInitMessageTask.prepareOperation() |
protected Operation |
SemaphoreDrainPermitsMessageTask.prepareOperation() |
protected Operation |
SemaphoreTryAcquireMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
SetContainsMessageTask.prepareOperation() |
protected Operation |
SetAddAllMessageTask.prepareOperation() |
protected Operation |
SetGetAllMessageTask.prepareOperation() |
protected Operation |
SetRemoveMessageTask.prepareOperation() |
protected Operation |
SetClearMessageTask.prepareOperation() |
protected Operation |
SetCompareAndRemoveAllMessageTask.prepareOperation() |
protected Operation |
SetSizeMessageTask.prepareOperation() |
protected Operation |
SetContainsAllMessageTask.prepareOperation() |
protected Operation |
SetAddMessageTask.prepareOperation() |
protected Operation |
SetIsEmptyMessageTask.prepareOperation() |
protected Operation |
SetCompareAndRetainAllMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
TopicPublishMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
XAFinalizeTransactionMessageTask.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected Supplier<Operation> |
XACollectTransactionsMessageTask.createOperationSupplier() |
Modifier and Type | Method and Description |
---|---|
void |
ClientInvokerWrapper.executeOperation(Operation op) |
Modifier and Type | Method and Description |
---|---|
static List<Operation> |
CollectionTxnUtil.read(ObjectDataInput in) |
static List<Operation> |
CollectionTxnUtil.run(List<Operation> operationList) |
Modifier and Type | Method and Description |
---|---|
static void |
CollectionTxnUtil.before(List<Operation> operationList,
Operation wrapper) |
Modifier and Type | Method and Description |
---|---|
static void |
CollectionTxnUtil.after(List<Operation> operationList) |
static void |
CollectionTxnUtil.before(List<Operation> operationList,
Operation wrapper) |
static List<Operation> |
CollectionTxnUtil.run(List<Operation> operationList) |
static void |
CollectionTxnUtil.write(ObjectDataOutput out,
List<Operation> operationList) |
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 |
CollectionReplicationOperation |
class |
CollectionSizeOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
CollectionMergeOperation.getBackupOperation() |
Operation |
CollectionCompareAndRemoveOperation.getBackupOperation() |
Operation |
CollectionAddAllOperation.getBackupOperation() |
Operation |
CollectionRemoveOperation.getBackupOperation() |
Operation |
CollectionClearOperation.getBackupOperation() |
Operation |
CollectionAddOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
ListService.prepareReplicationOperation(PartitionReplicationEvent event) |
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 | Method and Description |
---|---|
Operation |
ListSetOperation.getBackupOperation() |
Operation |
ListRemoveOperation.getBackupOperation() |
Operation |
ListAddOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
QueueService.prepareReplicationOperation(PartitionReplicationEvent event) |
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 |
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 |
QueueReplicationOperation
Replication operation for the Queue.
|
class |
RemainingCapacityOperation
Returns the remaining capacity of the queue based on config max-size
|
Modifier and Type | Method and Description |
---|---|
Operation |
QueueMergeOperation.getBackupOperation() |
Operation |
PollOperation.getBackupOperation() |
Operation |
OfferOperation.getBackupOperation() |
Operation |
RemoveOperation.getBackupOperation() |
Operation |
AddAllOperation.getBackupOperation() |
Operation |
ClearOperation.getBackupOperation() |
Operation |
CompareAndRemoveOperation.getBackupOperation() |
Operation |
DrainOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
SetService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
SetReplicationOperation |
Modifier and Type | Field and Description |
---|---|
protected List<Operation> |
CollectionTransactionLogRecord.operationList |
Modifier and Type | Method and Description |
---|---|
Operation |
CollectionTransactionLogRecord.newCommitOperation() |
Operation |
CollectionTransactionLogRecord.newPrepareOperation() |
Operation |
CollectionTransactionLogRecord.newRollbackOperation() |
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 | Method and Description |
---|---|
Operation |
CollectionPrepareOperation.getBackupOperation() |
Operation |
CollectionTxnRemoveOperation.getBackupOperation() |
Operation |
CollectionTxnAddOperation.getBackupOperation() |
Operation |
CollectionRollbackOperation.getBackupOperation() |
Operation |
CollectionCommitOperation.getBackupOperation() |
Constructor and Description |
---|
CollectionCommitBackupOperation(String name,
String serviceName,
List<Operation> backupList) |
CollectionCommitOperation(int partitionId,
String name,
String serviceName,
List<Operation> operationList) |
Modifier and Type | Method and Description |
---|---|
Operation |
QueueTransactionLogRecord.newCommitOperation() |
Operation |
QueueTransactionLogRecord.newPrepareOperation() |
Operation |
QueueTransactionLogRecord.newRollbackOperation() |
Modifier and Type | Class and Description |
---|---|
class |
BaseTxnQueueOperation |
class |
QueueTransactionRollbackOperation
Transaction Rollback Operation for the Queue.
|
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 | Method and Description |
---|---|
Operation |
TxnPrepareOperation.getBackupOperation() |
Operation |
TxnRollbackOperation.getBackupOperation() |
Operation |
TxnOfferOperation.getBackupOperation() |
Operation |
TxnReserveOfferOperation.getBackupOperation() |
Operation |
TxnCommitOperation.getBackupOperation() |
Operation |
TxnPollOperation.getBackupOperation() |
Operation |
TxnReservePollOperation.getBackupOperation() |
Constructor and Description |
---|
TxnCommitBackupOperation(String name,
List<Operation> backupList) |
TxnCommitOperation(int partitionId,
String name,
List<Operation> operationList) |
Modifier and Type | Method and Description |
---|---|
Operation |
AtomicLongService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAlterOperation |
class |
AbstractAtomicLongOperation |
class |
AddAndGetOperation |
class |
AddBackupOperation |
class |
AlterAndGetOperation |
class |
AlterOperation |
class |
ApplyOperation<R> |
class |
AtomicLongBackupAwareOperation |
class |
AtomicLongReplicationOperation |
class |
CompareAndSetOperation |
class |
GetAndAddOperation |
class |
GetAndAlterOperation |
class |
GetAndSetOperation |
class |
GetOperation |
class |
MergeBackupOperation
Creates backups for merged atomic longs after split-brain healing with a
SplitBrainMergePolicy . |
class |
SetBackupOperation |
class |
SetOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
SetOperation.getBackupOperation() |
Operation |
GetAndSetOperation.getBackupOperation() |
Operation |
AbstractAlterOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Operation |
CompareAndSetOperation.getBackupOperation() |
Operation |
AddAndGetOperation.getBackupOperation() |
Operation |
GetAndAddOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
AtomicReferenceService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAtomicReferenceOperation |
class |
AtomicReferenceBackupAwareOperation |
class |
AtomicReferenceReplicationOperation |
class |
ContainsOperation |
class |
IsNullOperation |
class |
SetAndGetOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
SetOperation.getBackupOperation() |
Operation |
GetAndSetOperation.getBackupOperation() |
Operation |
AbstractAlterOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Operation |
SetAndGetOperation.getBackupOperation() |
Operation |
CompareAndSetOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
CountDownLatchService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
CountDownLatchBackupOperation |
class |
CountDownLatchReplicationOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
LockServiceImpl.prepareReplicationOperation(PartitionReplicationEvent event) |
Operation |
LockServiceImpl.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLockOperation |
class |
AwaitBackupOperation |
class |
AwaitOperation |
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 | Method and Description |
---|---|
Operation |
LockOperation.getBackupOperation() |
Operation |
BeforeAwaitOperation.getBackupOperation() |
Operation |
UnlockOperation.getBackupOperation() |
Operation |
SignalOperation.getBackupOperation() |
Operation |
AwaitOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
SemaphoreService.prepareReplicationOperation(PartitionReplicationEvent event) |
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 |
class |
SemaphoreReplicationOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
InitOperation.getBackupOperation() |
Operation |
SemaphoreDetachMemberOperation.getBackupOperation() |
Operation |
ReleaseOperation.getBackupOperation() |
Operation |
ReduceOperation.getBackupOperation() |
Operation |
IncreaseOperation.getBackupOperation() |
Operation |
AcquireOperation.getBackupOperation() |
Operation |
DrainOperation.getBackupOperation() |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCRDTReplicationOperation<T extends IdentifiedDataSerializable>
Base class for CRDT replication operations.
|
Modifier and Type | Method and Description |
---|---|
Operation |
CRDTReplicationContainer.getOperation()
Returns the CRDT replication operation.
|
Constructor and Description |
---|
CRDTReplicationContainer(Operation operation,
Map<String,VectorClock> vectorClocks) |
Modifier and Type | Class and Description |
---|---|
class |
PNCounterReplicationOperation
CRDT replication operation for a
PNCounter . |
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 . |
Modifier and Type | Method and Description |
---|---|
Operation |
DurableExecutorPartitionContainer.prepareReplicationOperation(int replicaIndex) |
Operation |
DistributedDurableExecutorService.prepareReplicationOperation(PartitionReplicationEvent event) |
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 | Method and Description |
---|---|
Operation |
DisposeResultOperation.getBackupOperation() |
Operation |
PutResultOperation.getBackupOperation() |
Operation |
TaskOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
void |
DistributedExecutorService.execute(String name,
String uuid,
Callable callable,
Operation op) |
Modifier and Type | Class and Description |
---|---|
class |
CallableTaskOperation |
class |
CancellationOperation |
class |
MemberCallableTaskOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
ClusterStateTransactionLogRecord.newCommitOperation() |
Operation |
ClusterStateTransactionLogRecord.newPrepareOperation() |
Operation |
ClusterStateTransactionLogRecord.newRollbackOperation() |
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 |
MasterResponseOp
Operation sent by any node to set the master address on the receiver
|
class |
MemberAttributeChangedOp |
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 |
Constructor and Description |
---|
OnJoinOp(Operation... ops) |
Modifier and Type | Method and Description |
---|---|
static String |
OperationDescriptors.toOperationDesc(Operation op) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDynamicConfigOperation |
class |
AddDynamicConfigOperation |
class |
DynamicConfigPreJoinOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
AddDynamicConfigOperationSupplier.get() |
Operation |
ClusterWideConfigurationService.getPreJoinOperation() |
Constructor and Description |
---|
Merger(NodeEngine nodeEngine,
Operation replicationOperation) |
Modifier and Type | Method and Description |
---|---|
protected abstract Operation |
ClearExpiredRecordsTask.newBackupExpiryOp(S store,
Collection<ExpiredKey> expiredKeys) |
protected abstract Operation |
ClearExpiredRecordsTask.newPrimaryExpiryOp(int cleanupPercentage,
T container) |
Modifier and Type | Method and Description |
---|---|
void |
ClearExpiredRecordsTask.sendResponse(Operation op,
Object response) |
Modifier and Type | Class and Description |
---|---|
class |
EventJournalReadOperation<T,J>
Reads from the map event journal in batches.
|
Modifier and Type | Method and Description |
---|---|
InternalCompletableFuture<Object> |
ManagementCenterService.callOnAddress(Address address,
Operation operation) |
InternalCompletableFuture<Object> |
ManagementCenterService.callOnMember(Member member,
Operation operation) |
InternalCompletableFuture<Object> |
ManagementCenterService.callOnThis(Operation operation) |
void |
ManagementCenterService.send(Address address,
Operation operation) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractManagementOperation |
class |
AddWanConfigOperation
Operation to add a new
WanReplicationConfig at runtime. |
class |
ChangeWanStateOperation
Stop, pause or resume WAN replication for the given
wanReplicationName and targetGroupName . |
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. |
class |
WanCheckConsistencyOperation
Checking consistency of the given map for the given wan replication
schema and publisher
|
Modifier and Type | Method and Description |
---|---|
Collection<Operation> |
ReplicaFragmentMigrationState.getMigrationOperations() |
Modifier and Type | Method and Description |
---|---|
ServiceNamespace |
PartitionReplicaVersionManager.getServiceNamespace(Operation operation)
Returns
ServiceNamespace for given operation. |
Constructor and Description |
---|
ReplicaFragmentMigrationState(Map<ServiceNamespace,long[]> namespaces,
Collection<Operation> migrationOperations) |
Modifier and Type | Method and Description |
---|---|
ServiceNamespace |
PartitionReplicaManager.getServiceNamespace(Operation operation) |
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 |
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 |
---|---|
protected void |
MigrationOperation.prepareOperation(Operation op) |
Constructor and Description |
---|
PartitionReplicaSyncResponse(Collection<Operation> operations,
ServiceNamespace namespace,
long[] versions) |
Modifier and Type | Class and Description |
---|---|
class |
ClassDataFinderOperation |
class |
DeployClassesOperation
Operation to distribute class definitions uploaded from client to cluster
|
Modifier and Type | Method and Description |
---|---|
static LocalRetryableExecution |
InvocationUtil.executeLocallyWithRetry(NodeEngine nodeEngine,
Operation operation)
Constructs a local execution with retry logic.
|
void |
LocalRetryableExecution.sendResponse(Operation op,
Object response) |
Modifier and Type | Method and Description |
---|---|
static ICompletableFuture<Object> |
InvocationUtil.invokeOnStableClusterSerial(NodeEngine nodeEngine,
Supplier<? extends Operation> operationSupplier,
int maxRetries)
Invoke operation on all cluster members.
|
Modifier and Type | Method and Description |
---|---|
Operation |
MapService.getPostJoinOperation() |
Operation |
MapService.prepareReplicationOperation(PartitionReplicationEvent event) |
Operation |
MapService.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces) |
Modifier and Type | Method and Description |
---|---|
void |
MapServiceContext.incrementOperationStats(long startTime,
LocalMapStatsImpl localMapStats,
String mapName,
Operation operation) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
MapClearExpiredRecordsTask.newBackupExpiryOp(RecordStore store,
Collection<ExpiredKey> expiredKeys) |
protected Operation |
MapClearExpiredRecordsTask.newPrimaryExpiryOp(int expirationPercentage,
PartitionContainer container) |
Modifier and Type | Class and Description |
---|---|
class |
MapEventJournalReadOperation<K,V,T>
Reads from the map event journal in batches.
|
class |
MapEventJournalSubscribeOperation
Performs the initial subscription to the map event journal.
|
Modifier and Type | Class and Description |
---|---|
class |
AccumulatorConsumerOperation
Processes remaining items in
Accumulator instances on a partition. |
class |
AddIndexOperation |
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 |
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 |
MapGetInvalidationMetaDataOperation |
class |
MapIsEmptyOperation |
class |
MapOperation |
class |
MapPartitionDestroyOperation
Operation to destroy the map data on the partition thread
|
class |
MapReplicationOperation
Replicates all IMap-states of this partition to a replica partition.
|
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 |
PostJoinMapOperation |
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 |
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 | Method and Description |
---|---|
Operation |
ContainsValueOperationFactory.createOperation() |
Operation |
MapLoadAllOperationFactory.createOperation() |
Operation |
KeyLoadStatusOperationFactory.createOperation() |
Operation |
PartitionWideEntryOperationFactory.createOperation() |
Operation |
MapFlushOperationFactory.createOperation() |
Operation |
MultipleEntryOperationFactory.createOperation() |
Operation |
EvictAllOperationFactory.createOperation() |
Operation |
SizeOperationFactory.createOperation() |
Operation |
ClearOperationFactory.createOperation() |
Operation |
PartitionWideEntryWithPredicateOperationFactory.createOperation() |
Operation |
AddIndexOperationFactory.createOperation() |
Operation |
IsEmptyOperationFactory.createOperation() |
Operation |
MapGetAllOperationFactory.createOperation() |
Operation |
IsPartitionLoadedOperationFactory.createOperation() |
Operation |
MergeOperationFactory.createPartitionOperation(int partitionId) |
Operation |
PutAllPartitionAwareOperationFactory.createPartitionOperation(int partitionId) |
Operation |
PartitionWideEntryWithPredicateOperationFactory.createPartitionOperation(int partition) |
Operation |
MultipleEntryOperation.getBackupOperation() |
Operation |
SetTtlOperation.getBackupOperation() |
Operation |
EvictAllOperation.getBackupOperation() |
Operation |
BasePutOperation.getBackupOperation() |
Operation |
EntryOffloadableSetUnlockOperation.getBackupOperation() |
Operation |
PartitionWideEntryWithPredicateOperation.getBackupOperation() |
Operation |
PartitionWideEntryOperation.getBackupOperation() |
Operation |
MapFlushOperation.getBackupOperation() |
Operation |
LegacyMergeOperation.getBackupOperation() |
Operation |
EntryOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Operation |
ClearOperation.getBackupOperation() |
Operation |
MultipleEntryWithPredicateOperation.getBackupOperation() |
Operation |
BaseRemoveOperation.getBackupOperation() |
Operation |
PutAllOperation.getBackupOperation() |
Operation |
EvictOperation.getBackupOperation() |
Operation |
PutFromLoadAllOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
protected Object |
MapProxyImpl.invoke(Operation operation,
int partitionId) |
Modifier and Type | Class and Description |
---|---|
class |
QueryOperation |
class |
QueryPartitionOperation |
Modifier and Type | Method and Description |
---|---|
void |
InvokerWrapper.executeOperation(Operation op) |
void |
NodeInvokerWrapper.executeOperation(Operation operation) |
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 | Method and Description |
---|---|
Operation |
MadePublishableOperationFactory.createOperation() |
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 | Method and Description |
---|---|
Operation |
TxnPrepareOperation.getBackupOperation() |
Operation |
TxnRollbackOperation.getBackupOperation() |
Operation |
TxnUnlockOperation.getBackupOperation() |
Operation |
TxnDeleteOperation.getBackupOperation() |
Operation |
MapTransactionLogRecord.newCommitOperation() |
Operation |
MapTransactionLogRecord.newPrepareOperation() |
Operation |
MapTransactionLogRecord.newRollbackOperation() |
Constructor and Description |
---|
MapTransactionLogRecord(String name,
Data key,
int partitionId,
Operation op,
long version,
String ownerUuid) |
Modifier and Type | Method and Description |
---|---|
static <V> V |
MapReduceUtil.executeOperation(Operation operation,
Address address,
MapReduceService mapReduceService,
NodeEngine nodeEngine) |
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 |
KeysAssignmentOperation
This operation is used to request assignment for keys on the job owners node.
|
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 |
StartProcessingJobOperation<K>
This operation is used to start the actual processing after all node prepared to execute the map reduce job
|
Modifier and Type | Method and Description |
---|---|
Operation |
GetResultOperationFactory.createOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
MultiMapService.prepareReplicationOperation(PartitionReplicationEvent event) |
Operation |
MultiMapService.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBackupAwareMultiMapOperation |
class |
AbstractKeyBasedMultiMapOperation |
class |
AbstractMultiMapOperation |
class |
ClearBackupOperation |
class |
ClearOperation |
class |
ContainsEntryOperation |
class |
CountOperation |
class |
DeleteBackupOperation |
class |
DeleteOperation |
class |
EntrySetOperation |
class |
GetAllOperation |
class |
KeySetOperation |
class |
MultiMapReplicationOperation |
class |
PutBackupOperation |
class |
PutOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
RemoveBackupOperation |
class |
RemoveOperation |
class |
SizeOperation |
class |
ValuesOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
MultiMapOperationFactory.createOperation() |
Operation |
RemoveAllOperation.getBackupOperation() |
Operation |
DeleteOperation.getBackupOperation() |
Operation |
RemoveOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Operation |
ClearOperation.getBackupOperation() |
Operation |
PutOperation.getBackupOperation() |
Modifier and Type | Class and Description |
---|---|
class |
TxnCommitBackupOperation |
class |
TxnCommitOperation |
class |
TxnGenerateRecordIdOperation |
class |
TxnLockAndGetOperation |
class |
TxnPrepareBackupOperation |
class |
TxnPrepareOperation |
class |
TxnPutBackupOperation |
class |
TxnPutOperation |
class |
TxnRemoveAllBackupOperation |
class |
TxnRemoveAllOperation |
class |
TxnRemoveBackupOperation |
class |
TxnRemoveOperation |
class |
TxnRollbackBackupOperation |
class |
TxnRollbackOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
TxnPrepareOperation.getBackupOperation() |
Operation |
TxnRollbackOperation.getBackupOperation() |
Operation |
TxnPutOperation.getBackupOperation() |
Operation |
TxnRemoveOperation.getBackupOperation() |
Operation |
TxnCommitOperation.getBackupOperation() |
Operation |
TxnRemoveAllOperation.getBackupOperation() |
Operation |
MultiMapTransactionLogRecord.newCommitOperation() |
Operation |
MultiMapTransactionLogRecord.newPrepareOperation() |
Operation |
MultiMapTransactionLogRecord.newRollbackOperation() |
Modifier and Type | Method and Description |
---|---|
void |
MultiMapTransactionLogRecord.addOperation(Operation op) |
Constructor and Description |
---|
TxnCommitBackupOperation(String name,
Data dataKey,
List<Operation> opList,
String caller,
long threadId) |
TxnCommitOperation(int partitionId,
String name,
Data dataKey,
long threadId,
List<Operation> opList) |
Modifier and Type | Method and Description |
---|---|
void |
QuorumServiceImpl.ensureQuorumPresent(Operation op)
Ensures that the quorum for the given operation is present.
|
Modifier and Type | Method and Description |
---|---|
Operation |
ReplicatedMapService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedSerializableOperation |
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 |
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
|
Modifier and Type | Method and Description |
---|---|
Operation |
ClearOperationFactory.createOperation() |
Operation |
PutAllOperationFactory.createOperation() |
Operation |
MergeOperationFactory.createPartitionOperation(int partitionId) |
Modifier and Type | Method and Description |
---|---|
Operation |
RingbufferService.prepareReplicationOperation(PartitionReplicationEvent event) |
Operation |
RingbufferService.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces) |
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 |
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 |
MergeOperation
Contains an entire ringbuffer for split-brain healing with a
SplitBrainMergePolicy . |
class |
ReadManyOperation<O> |
class |
ReadOneOperation |
class |
ReplicationOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
AddOperation.getBackupOperation() |
Operation |
AddAllOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
ScheduledExecutorPartition.prepareReplicationOperation(int replicaIndex,
boolean migrationMode) |
Operation |
DistributedScheduledExecutorService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
ScheduledExecutorMemberOwnedContainer.createInvocationBuilder(Operation op) |
protected InvocationBuilder |
ScheduledExecutorContainer.createInvocationBuilder(Operation op) |
Constructor and Description |
---|
InvokeOnMembers(NodeEngine nodeEngine,
String serviceName,
Supplier<Operation> operationFactory,
Collection<Member> targets) |
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 |
ResultReadyNotifyOperation<V> |
class |
ScheduleTaskBackupOperation |
class |
ScheduleTaskOperation |
class |
SyncBackupStateOperation |
class |
SyncStateOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
GetAllScheduledOnPartitionOperationFactory.createOperation() |
Operation |
CancelTaskOperation.getBackupOperation() |
Operation |
ScheduleTaskOperation.getBackupOperation() |
Operation |
MergeOperation.getBackupOperation() |
Operation |
SyncStateOperation.getBackupOperation() |
Operation |
DisposeTaskOperation.getBackupOperation() |
Modifier and Type | Interface and Description |
---|---|
interface |
OperationResponseHandler<O extends Operation>
A handler for the
OperationService when it has calculated a response. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLocalOperation
Abstract class for local operations, which should not be serializable.
|
Modifier and Type | Field and Description |
---|---|
protected Operation |
InvocationBuilder.op |
Modifier and Type | Method and Description |
---|---|
Operation |
OperationFactory.createOperation()
Creates the operation.
|
Operation |
BackupAwareOperation.getBackupOperation()
Creates the
BackupOperation responsible for making the backup. |
Operation |
InvocationBuilder.getOp()
Gets the operation to execute.
|
Operation |
PostJoinAwareService.getPostJoinOperation()
Post join operations must be lock free, meaning no locks at all:
no partition locks, no key-based locks, no service level locks, no database interaction!
The
getPartitionId() method should return a negative value. |
Operation |
PreJoinAwareService.getPreJoinOperation()
An operation to be executed on the joining member before it is set as joined.
|
Operation |
Offload.offloadedOperation()
Returns the Operation that created this Offload.
|
Operation |
MigrationAwareService.prepareReplicationOperation(PartitionReplicationEvent event)
Returns an operation to replicate service data and/or state for a specific partition replica
on another cluster member.
|
Operation |
FragmentedMigrationAwareService.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces)
Returns an operation to replicate service data and/or state for a specific partition replica and namespaces
on another cluster member.
|
Operation |
Operation.setCallerUuid(String callerUuid) |
Operation |
Operation.setNodeEngine(NodeEngine nodeEngine) |
Operation |
Operation.setOperationResponseHandler(OperationResponseHandler responseHandler)
Sets the
OperationResponseHandler . |
Operation |
Operation.setPartitionId(int partitionId)
Sets the partition ID.
|
Operation |
Operation.setReplicaIndex(int replicaIndex) |
Operation |
Operation.setService(Object service) |
Operation |
Operation.setServiceName(String serviceName) |
Operation |
Operation.setValidateTarget(boolean validateTarget) |
Modifier and Type | Method and Description |
---|---|
InvocationBuilder |
OperationService.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
InvocationBuilder |
OperationService.createInvocationBuilder(String serviceName,
Operation op,
int partitionId) |
static boolean |
OperationAccessor.deactivate(Operation op)
Marks the supplied operation as "not active".
|
void |
OperationService.execute(Operation op)
Executes an operation in the operation executor pool.
|
static boolean |
OperationAccessor.hasActiveInvocation(Operation op) |
<E> InternalCompletableFuture<E> |
OperationService.invokeOnPartition(Operation op)
Executes an operation on a partition.
|
protected <E> InternalCompletableFuture<E> |
AbstractDistributedObject.invokeOnPartition(Operation operation) |
<E> InternalCompletableFuture<E> |
OperationService.invokeOnPartition(String serviceName,
Operation op,
int partitionId) |
<E> InternalCompletableFuture<E> |
OperationService.invokeOnTarget(String serviceName,
Operation op,
Address target) |
void |
OperationService.run(Operation op)
Runs an operation in the calling thread.
|
boolean |
OperationService.send(Operation op,
Address target)
Executes an operation remotely.
|
static void |
OperationAccessor.setCallerAddress(Operation op,
Address caller) |
static void |
OperationAccessor.setCallId(Operation op,
long callId)
Assigns the supplied call ID to the supplied operation, thereby activating it.
|
static void |
OperationAccessor.setCallTimeout(Operation op,
long callTimeout)
Sets the call timeout in milliseconds for the Operation.
|
static void |
OperationAccessor.setConnection(Operation op,
Connection connection) |
static void |
OperationAccessor.setInvocationTime(Operation op,
long invocationTime)
Sets the invocation time for the Operation.
|
Modifier and Type | Method and Description |
---|---|
void |
Offload.init(NodeEngineImpl nodeEngine,
Set<Operation> asyncOperations)
Initializes the Offload.
|
Constructor and Description |
---|
InvocationBuilder(String serviceName,
Operation op,
int partitionId,
Address target)
Creates an InvocationBuilder
|
Offload(Operation offloadedOperation)
Creates a new Offload instance.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
BinaryOperationFactory.createOperation() |
Operation[] |
NodeEngineImpl.getPostJoinOperations()
Collects all post-join operations from
PostJoinAwareService s. |
Operation[] |
NodeEngineImpl.getPreJoinOperations() |
Operation |
CountingMigrationAwareService.prepareReplicationOperation(PartitionReplicationEvent event) |
Operation |
CountingMigrationAwareService.prepareReplicationOperation(PartitionReplicationEvent event,
Collection<ServiceNamespace> namespaces) |
Constructor and Description |
---|
BinaryOperationFactory(Operation operation,
NodeEngine nodeEngine) |
Modifier and Type | Method and Description |
---|---|
Operation |
EventServiceImpl.getPostJoinOperation() |
Operation |
EventServiceImpl.getPreJoinOperation() |
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 | Method and Description |
---|---|
Operation |
RegistrationOperationSupplier.get() |
Operation |
DeregistrationOperationSupplier.get() |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractContainerMerger.invoke(String serviceName,
Operation operation,
int partitionId)
Invokes the given merge operation.
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
AbstractMergeRunnable.mergeStoreLegacy(Store recordStore,
BiConsumer<Integer,Operation> consumer)
Used to merge with legacy merge policies.
|
Modifier and Type | Method and Description |
---|---|
void |
OperationExecutor.execute(Operation op)
Executes the given
Operation at some point in the future. |
boolean |
OperationExecutor.isInvocationAllowed(Operation op,
boolean isAsync)
Checks if the
Operation is allowed to be invoked from the current
thread. |
boolean |
OperationExecutor.isRunAllowed(Operation op)
Checks if the
Operation is allowed to run on the current thread. |
abstract void |
OperationRunner.run(Operation task) |
void |
OperationExecutor.run(Operation op)
Runs the
Operation on the calling thread. |
void |
OperationExecutor.runOrExecute(Operation op)
Tries to run the
Operation on the calling thread if allowed. |
Modifier and Type | Method and Description |
---|---|
void |
OperationExecutorImpl.execute(Operation op) |
boolean |
OperationExecutorImpl.isInvocationAllowed(Operation op,
boolean isAsync) |
boolean |
OperationExecutorImpl.isRunAllowed(Operation op) |
void |
OperationExecutorImpl.run(Operation operation) |
void |
OperationExecutorImpl.runOrExecute(Operation op) |
Modifier and Type | Method and Description |
---|---|
<V> void |
InternalOperationService.asyncInvokeOnPartition(String serviceName,
Operation op,
int partitionId,
ExecutionCallback<V> callback) |
boolean |
InternalOperationService.isCallTimedOut(Operation op)
Checks if this call is timed out.
|
boolean |
InternalOperationService.isRunAllowed(Operation op)
Returns true if the given operation is allowed to run on the calling
thread, false otherwise.
|
void |
InternalOperationService.onCompletionAsyncOperation(Operation op)
Should be called when the asynchronous operation has completed.
|
void |
InternalOperationService.onStartAsyncOperation(Operation op)
Should be called when an asynchronous operations not running on a operation thread is running.
|
Modifier and Type | Field and Description |
---|---|
Operation |
Invocation.op
The
Operation this invocation is evaluating. |
Modifier and Type | Method and Description |
---|---|
<V> void |
OperationServiceImpl.asyncInvokeOnPartition(String serviceName,
Operation op,
int partitionId,
ExecutionCallback<V> callback) |
InvocationBuilder |
OperationServiceImpl.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
InvocationBuilder |
OperationServiceImpl.createInvocationBuilder(String serviceName,
Operation op,
int partitionId) |
void |
OperationServiceImpl.execute(Operation op) |
<E> InternalCompletableFuture<E> |
OperationServiceImpl.invokeOnPartition(Operation op) |
<E> InternalCompletableFuture<E> |
OperationServiceImpl.invokeOnPartition(String serviceName,
Operation op,
int partitionId) |
<E> InternalCompletableFuture<E> |
OperationServiceImpl.invokeOnTarget(String serviceName,
Operation op,
Address target) |
boolean |
OperationServiceImpl.isCallTimedOut(Operation op) |
boolean |
OperationServiceImpl.isRunAllowed(Operation op) |
void |
OperationServiceImpl.onCompletionAsyncOperation(Operation op) |
void |
OperationServiceImpl.onStartAsyncOperation(Operation op) |
void |
OperationServiceImpl.run(Operation op) |
boolean |
OperationServiceImpl.send(Operation op,
Address target) |
boolean |
OutboundOperationHandler.send(Operation op,
Address target) |
boolean |
OutboundOperationHandler.send(Operation op,
Connection connection) |
void |
Invocation.sendResponse(Operation op,
Object response) |
void |
OutboundResponseHandler.sendResponse(Operation operation,
Object obj) |
Modifier and Type | Class and Description |
---|---|
class |
Backup |
class |
PartitionIteratingOperation
Executes Operations on one or more partitions.
|
Modifier and Type | Method and Description |
---|---|
Operation |
PartitionAwareOperationFactory.createOperation() |
abstract Operation |
PartitionAwareOperationFactory.createPartitionOperation(int partition)
This method can be called both caller and runner nodes.
|
Operation |
Backup.getBackupOp() |
Constructor and Description |
---|
Backup(Operation backupOp,
Address originalCaller,
long[] replicaVersions,
boolean sync) |
Modifier and Type | Method and Description |
---|---|
static boolean |
Operations.isJoinOperation(Operation op) |
static boolean |
Operations.isMigrationOperation(Operation op) |
static boolean |
Operations.isWanReplicationOperation(Operation op)
Checks if the given operation is an instance of
WanReplicationOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
ProxyServiceImpl.getPostJoinOperation() |
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).
|
Modifier and Type | Method and Description |
---|---|
Operation |
TransactionLogRecord.newCommitOperation() |
Operation |
TransactionLogRecord.newPrepareOperation() |
Operation |
TransactionLogRecord.newRollbackOperation() |
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 | Method and Description |
---|---|
Operation |
XAService.prepareReplicationOperation(PartitionReplicationEvent event) |
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 | Method and Description |
---|---|
Operation |
FinalizeRemoteTransactionOperation.getBackupOperation() |
Operation |
ClearRemoteTransactionOperation.getBackupOperation() |
Operation |
PutRemoteTransactionOperation.getBackupOperation() |
Copyright © 2018 Hazelcast, Inc.. All Rights Reserved.