|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Packages that use Operation | |
|---|---|
| com.hazelcast.cache.impl | Hazelcast JSR-107 aka JCache implementation |
| com.hazelcast.cache.impl.client | Hazelcast JSR-107 aka JCache implementation Client Requests |
| com.hazelcast.cache.impl.operation | Hazelcast JSR-107 aka JCache implementation |
| com.hazelcast.client.impl | Contains most of the client side HazelcastInstance implementation functionality. |
| com.hazelcast.client.impl.client | This contains the Requests and other DTO's exchanged between client/server |
| com.hazelcast.client.impl.operations | Contains client operations |
| com.hazelcast.cluster.impl.operations | This package contains operations for the com.hazelcast.cluster.impl package. |
| com.hazelcast.collection | This package contains classes related to Collections (IList,ISet etc..) |
| com.hazelcast.collection.client | This package contains client functionality for Collections in Hazelcast. |
| com.hazelcast.collection.list | This package contains IList functionality for Hazelcast. |
| com.hazelcast.collection.set | This package contains ISet functionality for Hazelcast. |
| com.hazelcast.collection.txn | This package contains the Transaction behavior for the Collections. |
| com.hazelcast.concurrent.atomiclong | This package contains IAtomicLong functionality for Hazelcast. The IAtomicLong is the distributed version of the AtomicLong. |
| com.hazelcast.concurrent.atomiclong.client | This package contains client requests for the IAtomicLong. This package contains all the client request object to operate on the IAtomicLong that are send by the client. |
| 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.client | This package contains client requests for the IAtomicLong. This package contains all the client request object to operate on the IAtomicLong that are send by the client. |
| 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.client | This package contains client requests for the ICountDownLatch. This package contains all the client requests object to operate on the ICountDownLatch that are send by the client. |
| com.hazelcast.concurrent.countdownlatch.operations | This package contains the operations on the ICountDownLatch. |
| com.hazelcast.concurrent.lock | This package contains Lock for Hazelcast. The ILock is the distributed version of the Lock. |
| com.hazelcast.concurrent.lock.client | This package contains client requests for the ILock. This package contains all the client requests object to operate on the ILock that are send by the client. |
| 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.client | This package contains client requests for the ISemaphore. |
| com.hazelcast.concurrent.semaphore.operations | This package contains the operations on the ISemaphore. |
| com.hazelcast.executor.impl.client | This package contains client requests for the IExecutorService. |
| com.hazelcast.executor.impl.operations | This package contains operations for the IExecutorService. |
| com.hazelcast.management | Contains classes to provide data/operation interface for Management Center. |
| com.hazelcast.management.operation | Contains operations that are called from Management Center. |
| com.hazelcast.map.impl | Contains implementation specific classes of com.hazelcast.map package. |
| com.hazelcast.map.impl.client | Contains client requests for the IMap |
| 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.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.client | Contains client requests 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.partition.impl | Contains the actual implementation of the InternalPartitionService. |
| com.hazelcast.queue.impl | This package contains the IQueue functionality. The IQueue is the distributed version of the BlockingQueue. |
| com.hazelcast.queue.impl.client | This package contains client requests for the IQueue. |
| com.hazelcast.queue.impl.operations | This package contains the IQueue operations |
| com.hazelcast.queue.impl.tx | This package contains the Transaction behavior for the IQueue. |
| com.hazelcast.replicatedmap.impl.operation | This package contains some remote operations to execute on remote nodes |
| com.hazelcast.spi | Provides interfaces/classes for Hazelcast SPI. |
| com.hazelcast.spi.impl | Contains implementations for Hazelcast SPI. |
| com.hazelcast.topic.impl | This package contains ITopic functionality for Hazelcast. With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
| com.hazelcast.topic.impl.client | This package contains client requests for the ITopic. |
| com.hazelcast.transaction.impl | Provides implementation for Hazelcast transaction support. |
| Uses of Operation in com.hazelcast.cache.impl |
|---|
| Methods in com.hazelcast.cache.impl that return Operation | |
|---|---|
Operation |
CacheOperationProvider.createContainsKeyOperation(Data key)
|
Operation |
DefaultOperationProvider.createContainsKeyOperation(Data key)
|
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.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 |
CacheService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.cache.impl.client |
|---|
| Methods in com.hazelcast.cache.impl.client that return Operation | |
|---|---|
protected Operation |
CacheListenerRegistrationRequest.prepareOperation()
|
protected Operation |
CachePutRequest.prepareOperation()
|
protected Operation |
CacheRemoveRequest.prepareOperation()
|
protected Operation |
CacheReplaceRequest.prepareOperation()
|
protected Operation |
CacheDestroyRequest.prepareOperation()
|
protected Operation |
CachePutIfAbsentRequest.prepareOperation()
|
protected Operation |
CacheIterateRequest.prepareOperation()
|
protected Operation |
CacheGetAndRemoveRequest.prepareOperation()
|
protected Operation |
CacheGetConfigRequest.prepareOperation()
|
protected Operation |
CacheGetRequest.prepareOperation()
|
protected Operation |
CacheContainsKeyRequest.prepareOperation()
|
protected Operation |
CacheGetAndReplaceRequest.prepareOperation()
|
protected Operation |
CacheEntryProcessorRequest.prepareOperation()
|
protected Operation |
CacheCreateConfigRequest.prepareOperation()
|
protected Operation |
CacheManagementConfigRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.cache.impl.operation |
|---|
| Subclasses of Operation in com.hazelcast.cache.impl.operation | |
|---|---|
class |
AbstractMutatingCacheOperation
Base class for all mutable cache operations. |
class |
CacheBackupEntryProcessorOperation
Operation of the Cache Backup Entry Processor. |
class |
CacheClearBackupOperation
Backup operation of CacheClearOperation. |
class |
CacheClearOperation
Cache Clear will clear all internal cache data without sending any event |
class |
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key. |
class |
CacheCreateConfigOperation
Used to create cluster wide cache configuration. |
class |
CacheDestroyOperation
Destroys the cache on the cluster or on a single node by calling AbstractCacheService.destroyCache(String, boolean, String). |
class |
CacheEntryProcessorOperation
Operation of the Cache Entry Processor. |
class |
CacheGetAllOperation
Gets all keys from the cache. |
class |
CacheGetAndRemoveOperation
Cache GetAndRemove Operation. |
class |
CacheGetAndReplaceOperation
Cache GetAndReplace Operation. |
class |
CacheGetConfigOperation
Cache GetConfig Operation. |
class |
CacheGetOperation
Cache Get Operation. |
class |
CacheKeyIteratorOperation
Provides iterator functionality for ICache. |
class |
CacheListenerRegistrationOperation
Listener can be registered and unregistered by CacheService. |
class |
CacheLoadAllOperation
Loads all entries of the keys to partition record store ICacheRecordStore. |
class |
CacheManagementConfigOperation
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and statistics mxbeans of the cache. |
class |
CachePutAllBackupOperation
Cache PutAllBackup Operation is the backup operation used by load all operation. |
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 com.hazelcast.cache.impl.ICacheRecordStore#put(Data, Object, ExpiryPolicy, String) and
com.hazelcast.cache.impl.ICacheRecordStore#getAndPut(Data, Object, ExpiryPolicy, String). |
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 |
CacheSizeOperation
This operation implementation is for calculating the cluster size of a named cache. |
| Methods in com.hazelcast.cache.impl.operation that return Operation | |
|---|---|
Operation |
CacheClearOperationFactory.createOperation()
|
Operation |
CacheGetAllOperationFactory.createOperation()
|
Operation |
CacheSizeOperationFactory.createOperation()
|
Operation |
CacheRemoveAllOperationFactory.createOperation()
|
Operation |
CacheLoadAllOperationFactory.createOperation()
|
Operation |
CacheGetAndRemoveOperation.getBackupOperation()
|
Operation |
CacheLoadAllOperation.getBackupOperation()
|
Operation |
CacheClearOperation.getBackupOperation()
|
Operation |
CacheRemoveAllOperation.getBackupOperation()
|
Operation |
CachePutOperation.getBackupOperation()
|
Operation |
CacheReplaceOperation.getBackupOperation()
|
Operation |
CacheRemoveOperation.getBackupOperation()
|
Operation |
CacheEntryProcessorOperation.getBackupOperation()
|
Operation |
CacheGetAndReplaceOperation.getBackupOperation()
|
Operation |
CachePutIfAbsentOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.client.impl |
|---|
| Methods in com.hazelcast.client.impl that return Operation | |
|---|---|
Operation |
ClientEngineImpl.getPostJoinOperation()
|
| Uses of Operation in com.hazelcast.client.impl.client |
|---|
| Methods in com.hazelcast.client.impl.client that return Operation | |
|---|---|
protected abstract Operation |
PartitionClientRequest.prepareOperation()
|
protected abstract Operation |
TargetClientRequest.prepareOperation()
|
| Methods in com.hazelcast.client.impl.client with parameters of type Operation | |
|---|---|
protected InvocationBuilder |
InvocationClientRequest.createInvocationBuilder(String serviceName,
Operation op,
Address target)
|
protected InvocationBuilder |
InvocationClientRequest.createInvocationBuilder(String serviceName,
Operation op,
int partitionId)
|
| Uses of Operation in com.hazelcast.client.impl.operations |
|---|
| Subclasses of Operation in com.hazelcast.client.impl.operations | |
|---|---|
class |
ClientDisconnectionOperation
|
class |
ClientReAuthOperation
|
class |
PostJoinClientOperation
|
| Methods in com.hazelcast.client.impl.operations that return Operation | |
|---|---|
Operation |
OperationFactoryWrapper.createOperation()
|
| Uses of Operation in com.hazelcast.cluster.impl.operations |
|---|
| Subclasses of Operation in com.hazelcast.cluster.impl.operations | |
|---|---|
class |
AuthenticationFailureOperation
|
class |
AuthorizationOperation
|
class |
ConfigMismatchOperation
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated. |
class |
FinalizeJoinOperation
|
class |
GroupMismatchOperation
|
class |
HeartbeatOperation
|
class |
JoinCheckOperation
|
class |
JoinRequestOperation
|
class |
MasterClaimOperation
|
class |
MasterConfirmationOperation
|
class |
MasterDiscoveryOperation
|
class |
MemberAttributeChangedOperation
|
class |
MemberInfoUpdateOperation
|
class |
MemberRemoveOperation
|
class |
MergeClustersOperation
|
class |
PostJoinOperation
|
class |
PrepareMergeOperation
|
class |
SetMasterOperation
|
| Constructors in com.hazelcast.cluster.impl.operations with parameters of type Operation | |
|---|---|
PostJoinOperation(Operation... ops)
|
|
| Uses of Operation in com.hazelcast.collection |
|---|
| Subclasses of Operation in com.hazelcast.collection | |
|---|---|
class |
CollectionAddAllBackupOperation
|
class |
CollectionAddAllOperation
|
class |
CollectionAddBackupOperation
|
class |
CollectionAddOperation
|
class |
CollectionBackupAwareOperation
|
class |
CollectionClearBackupOperation
|
class |
CollectionClearOperation
|
class |
CollectionCompareAndRemoveOperation
|
class |
CollectionContainsOperation
|
class |
CollectionGetAllOperation
|
class |
CollectionIsEmptyOperation
|
class |
CollectionOperation
|
class |
CollectionRemoveBackupOperation
|
class |
CollectionRemoveOperation
|
class |
CollectionReplicationOperation
|
class |
CollectionSizeOperation
|
class |
CollectionTransactionRollbackOperation
|
| Methods in com.hazelcast.collection that return Operation | |
|---|---|
Operation |
CollectionCompareAndRemoveOperation.getBackupOperation()
|
Operation |
CollectionAddAllOperation.getBackupOperation()
|
Operation |
CollectionRemoveOperation.getBackupOperation()
|
Operation |
CollectionClearOperation.getBackupOperation()
|
Operation |
CollectionAddOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.collection.client |
|---|
| Methods in com.hazelcast.collection.client that return Operation | |
|---|---|
protected Operation |
CollectionGetAllRequest.prepareOperation()
|
protected Operation |
CollectionCompareAndRemoveRequest.prepareOperation()
|
protected Operation |
ListSetRequest.prepareOperation()
|
protected Operation |
ListRemoveRequest.prepareOperation()
|
protected Operation |
ListGetRequest.prepareOperation()
|
protected Operation |
ListSubRequest.prepareOperation()
|
protected Operation |
ListIndexOfRequest.prepareOperation()
|
protected Operation |
CollectionContainsRequest.prepareOperation()
|
protected Operation |
ListAddAllRequest.prepareOperation()
|
protected Operation |
CollectionAddAllRequest.prepareOperation()
|
protected Operation |
ListAddRequest.prepareOperation()
|
protected Operation |
CollectionAddRequest.prepareOperation()
|
protected Operation |
CollectionClearRequest.prepareOperation()
|
protected Operation |
CollectionSizeRequest.prepareOperation()
|
protected Operation |
CollectionIsEmptyRequest.prepareOperation()
|
protected Operation |
CollectionRemoveRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.collection.list |
|---|
| Subclasses of Operation in com.hazelcast.collection.list | |
|---|---|
class |
ListAddAllOperation
|
class |
ListAddOperation
|
class |
ListGetOperation
|
class |
ListIndexOfOperation
|
class |
ListRemoveOperation
|
class |
ListReplicationOperation
|
class |
ListSetBackupOperation
|
class |
ListSetOperation
|
class |
ListSubOperation
|
| Methods in com.hazelcast.collection.list that return Operation | |
|---|---|
Operation |
ListSetOperation.getBackupOperation()
|
Operation |
ListRemoveOperation.getBackupOperation()
|
Operation |
ListAddOperation.getBackupOperation()
|
Operation |
ListService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.collection.set |
|---|
| Subclasses of Operation in com.hazelcast.collection.set | |
|---|---|
class |
SetReplicationOperation
|
| Methods in com.hazelcast.collection.set that return Operation | |
|---|---|
Operation |
SetService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.collection.txn |
|---|
| Subclasses of Operation in com.hazelcast.collection.txn | |
|---|---|
class |
CollectionPrepareBackupOperation
|
class |
CollectionPrepareOperation
|
class |
CollectionReserveAddOperation
|
class |
CollectionReserveRemoveOperation
|
class |
CollectionRollbackBackupOperation
|
class |
CollectionRollbackOperation
|
class |
CollectionTxnAddBackupOperation
|
class |
CollectionTxnAddOperation
|
class |
CollectionTxnRemoveBackupOperation
|
class |
CollectionTxnRemoveOperation
|
| Methods in com.hazelcast.collection.txn that return Operation | |
|---|---|
Operation |
CollectionPrepareOperation.getBackupOperation()
|
Operation |
CollectionTxnRemoveOperation.getBackupOperation()
|
Operation |
CollectionTxnAddOperation.getBackupOperation()
|
Operation |
CollectionRollbackOperation.getBackupOperation()
|
| Constructors in com.hazelcast.collection.txn with parameters of type Operation | |
|---|---|
CollectionTransactionLog(long itemId,
String name,
int partitionId,
String serviceName,
String transactionId,
Operation op)
|
|
| Uses of Operation in com.hazelcast.concurrent.atomiclong |
|---|
| Methods in com.hazelcast.concurrent.atomiclong that return Operation | |
|---|---|
Operation |
AtomicLongService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.concurrent.atomiclong.client |
|---|
| Methods in com.hazelcast.concurrent.atomiclong.client that return Operation | |
|---|---|
protected Operation |
GetAndAlterRequest.prepareOperation()
|
protected Operation |
ApplyRequest.prepareOperation()
|
protected Operation |
AlterAndGetRequest.prepareOperation()
|
protected Operation |
GetAndSetRequest.prepareOperation()
|
protected Operation |
AddAndGetRequest.prepareOperation()
|
protected Operation |
GetAndAddRequest.prepareOperation()
|
protected Operation |
SetRequest.prepareOperation()
|
protected Operation |
AlterRequest.prepareOperation()
|
protected Operation |
CompareAndSetRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.concurrent.atomiclong.operations |
|---|
| Subclasses of Operation in com.hazelcast.concurrent.atomiclong.operations | |
|---|---|
class |
AbstractAlterOperation
|
class |
AddAndGetOperation
|
class |
AddBackupOperation
|
class |
AlterAndGetOperation
|
class |
AlterOperation
|
class |
ApplyOperation<R>
|
class |
AtomicLongBackupAwareOperation
|
class |
AtomicLongBaseOperation
|
class |
AtomicLongReplicationOperation
|
class |
CompareAndSetOperation
|
class |
GetAndAddOperation
|
class |
GetAndAlterOperation
|
class |
GetAndSetOperation
|
class |
GetOperation
|
class |
SetBackupOperation
|
class |
SetOperation
|
| Methods in com.hazelcast.concurrent.atomiclong.operations that return Operation | |
|---|---|
Operation |
SetOperation.getBackupOperation()
|
Operation |
GetAndSetOperation.getBackupOperation()
|
Operation |
AbstractAlterOperation.getBackupOperation()
|
Operation |
CompareAndSetOperation.getBackupOperation()
|
Operation |
AddAndGetOperation.getBackupOperation()
|
Operation |
GetAndAddOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.concurrent.atomicreference |
|---|
| Methods in com.hazelcast.concurrent.atomicreference that return Operation | |
|---|---|
Operation |
AtomicReferenceService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.concurrent.atomicreference.client |
|---|
| Methods in com.hazelcast.concurrent.atomicreference.client that return Operation | |
|---|---|
protected Operation |
GetAndAlterRequest.prepareOperation()
|
protected Operation |
ApplyRequest.prepareOperation()
|
protected Operation |
IsNullRequest.prepareOperation()
|
protected Operation |
GetRequest.prepareOperation()
|
protected Operation |
AlterAndGetRequest.prepareOperation()
|
protected Operation |
GetAndSetRequest.prepareOperation()
|
protected Operation |
SetRequest.prepareOperation()
|
protected Operation |
AlterRequest.prepareOperation()
|
protected Operation |
ContainsRequest.prepareOperation()
|
protected Operation |
CompareAndSetRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.concurrent.atomicreference.operations |
|---|
| Subclasses of Operation in com.hazelcast.concurrent.atomicreference.operations | |
|---|---|
class |
AtomicReferenceBackupAwareOperation
|
class |
AtomicReferenceBaseOperation
|
class |
AtomicReferenceReplicationOperation
|
class |
ContainsOperation
|
class |
IsNullOperation
|
class |
SetAndGetOperation
|
| Methods in com.hazelcast.concurrent.atomicreference.operations that return Operation | |
|---|---|
Operation |
SetOperation.getBackupOperation()
|
Operation |
GetAndSetOperation.getBackupOperation()
|
Operation |
AbstractAlterOperation.getBackupOperation()
|
Operation |
SetAndGetOperation.getBackupOperation()
|
Operation |
CompareAndSetOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.concurrent.countdownlatch |
|---|
| Methods in com.hazelcast.concurrent.countdownlatch that return Operation | |
|---|---|
Operation |
CountDownLatchService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.concurrent.countdownlatch.client |
|---|
| Methods in com.hazelcast.concurrent.countdownlatch.client that return Operation | |
|---|---|
protected Operation |
SetCountRequest.prepareOperation()
|
protected Operation |
CountDownRequest.prepareOperation()
|
protected Operation |
AwaitRequest.prepareOperation()
|
protected Operation |
GetCountRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.concurrent.countdownlatch.operations |
|---|
| Subclasses of Operation in com.hazelcast.concurrent.countdownlatch.operations | |
|---|---|
class |
CountDownLatchBackupOperation
|
class |
CountDownLatchReplicationOperation
|
class |
CountDownOperation
|
class |
GetCountOperation
|
class |
SetCountOperation
|
| Uses of Operation in com.hazelcast.concurrent.lock |
|---|
| Methods in com.hazelcast.concurrent.lock that return Operation | |
|---|---|
Operation |
LockServiceImpl.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.concurrent.lock.client |
|---|
| Methods in com.hazelcast.concurrent.lock.client that return Operation | |
|---|---|
protected Operation |
BeforeAwaitRequest.prepareOperation()
|
protected Operation |
GetRemainingLeaseRequest.prepareOperation()
|
protected Operation |
AbstractLockRequest.prepareOperation()
|
protected Operation |
GetLockCountRequest.prepareOperation()
|
protected Operation |
AbstractUnlockRequest.prepareOperation()
|
protected Operation |
SignalRequest.prepareOperation()
|
protected Operation |
AbstractIsLockedRequest.prepareOperation()
|
protected Operation |
AwaitRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.concurrent.lock.operations |
|---|
| Subclasses of Operation in com.hazelcast.concurrent.lock.operations | |
|---|---|
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
|
| Methods in com.hazelcast.concurrent.lock.operations that return Operation | |
|---|---|
Operation |
LockOperation.getBackupOperation()
|
Operation |
BeforeAwaitOperation.getBackupOperation()
|
Operation |
UnlockOperation.getBackupOperation()
|
Operation |
SignalOperation.getBackupOperation()
|
Operation |
AwaitOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.concurrent.semaphore |
|---|
| Methods in com.hazelcast.concurrent.semaphore that return Operation | |
|---|---|
Operation |
SemaphoreService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.concurrent.semaphore.client |
|---|
| Methods in com.hazelcast.concurrent.semaphore.client that return Operation | |
|---|---|
protected Operation |
DrainRequest.prepareOperation()
|
protected Operation |
ReleaseRequest.prepareOperation()
|
protected Operation |
InitRequest.prepareOperation()
|
protected Operation |
AcquireRequest.prepareOperation()
|
protected Operation |
ReduceRequest.prepareOperation()
|
protected Operation |
AvailableRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.concurrent.semaphore.operations |
|---|
| Subclasses of Operation in com.hazelcast.concurrent.semaphore.operations | |
|---|---|
class |
AcquireBackupOperation
|
class |
AcquireOperation
|
class |
AvailableOperation
|
class |
DeadMemberBackupOperation
|
class |
DrainBackupOperation
|
class |
DrainOperation
|
class |
InitBackupOperation
|
class |
InitOperation
|
class |
ReduceBackupOperation
|
class |
ReduceOperation
|
class |
ReleaseBackupOperation
|
class |
ReleaseOperation
|
class |
SemaphoreBackupAwareOperation
|
class |
SemaphoreBackupOperation
|
class |
SemaphoreDeadMemberOperation
|
class |
SemaphoreOperation
|
class |
SemaphoreReplicationOperation
|
| Methods in com.hazelcast.concurrent.semaphore.operations that return Operation | |
|---|---|
Operation |
SemaphoreDeadMemberOperation.getBackupOperation()
|
Operation |
InitOperation.getBackupOperation()
|
Operation |
ReleaseOperation.getBackupOperation()
|
Operation |
ReduceOperation.getBackupOperation()
|
Operation |
AcquireOperation.getBackupOperation()
|
Operation |
DrainOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.executor.impl.client |
|---|
| Methods in com.hazelcast.executor.impl.client that return Operation | |
|---|---|
protected Operation |
PartitionCallableRequest.prepareOperation()
|
protected Operation |
TargetCallableRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.executor.impl.operations |
|---|
| Subclasses of Operation in com.hazelcast.executor.impl.operations | |
|---|---|
class |
CallableTaskOperation
|
class |
CancellationOperation
|
class |
MemberCallableTaskOperation
|
class |
ShutdownOperation
|
| Uses of Operation in com.hazelcast.management |
|---|
| Methods in com.hazelcast.management with parameters of type Operation | |
|---|---|
Object |
ManagementCenterService.callOnAddress(Address address,
Operation operation)
|
Object |
ManagementCenterService.callOnMember(Member member,
Operation operation)
|
Object |
ManagementCenterService.callOnThis(Operation operation)
|
void |
ManagementCenterService.send(Address address,
Operation operation)
|
| Uses of Operation in com.hazelcast.management.operation |
|---|
| Subclasses of Operation in com.hazelcast.management.operation | |
|---|---|
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. |
| Uses of Operation in com.hazelcast.map.impl |
|---|
| Methods in com.hazelcast.map.impl that return Operation | |
|---|---|
Operation |
MapService.getPostJoinOperation()
|
Operation |
MapService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.map.impl.client |
|---|
| Methods in com.hazelcast.map.impl.client that return Operation | |
|---|---|
protected Operation |
MapSetRequest.prepareOperation()
|
protected Operation |
MapTryPutRequest.prepareOperation()
|
protected Operation |
MapPutIfAbsentRequest.prepareOperation()
|
protected Operation |
MapReplaceRequest.prepareOperation()
|
protected Operation |
MapExecuteOnKeyRequest.prepareOperation()
|
protected Operation |
MapGetEntryViewRequest.prepareOperation()
|
protected Operation |
MapPutRequest.prepareOperation()
|
protected Operation |
MapReplaceIfSameRequest.prepareOperation()
|
protected Operation |
MapRemoveRequest.prepareOperation()
|
protected Operation |
MapEvictRequest.prepareOperation()
|
protected Operation |
MapGetRequest.prepareOperation()
|
protected Operation |
MapRemoveIfSameRequest.prepareOperation()
|
protected Operation |
MapTryRemoveRequest.prepareOperation()
|
protected Operation |
MapDeleteRequest.prepareOperation()
|
protected Operation |
MapPutTransientRequest.prepareOperation()
|
protected Operation |
MapContainsKeyRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.map.impl.operation |
|---|
| Methods in com.hazelcast.map.impl.operation that return Operation | |
|---|---|
Operation |
ContainsValueOperationFactory.createOperation()
|
Operation |
PartitionCheckIfLoadedOperationFactory.createOperation()
|
Operation |
EntrySetOperationFactory.createOperation()
|
Operation |
MapKeySetOperationFactory.createOperation()
|
Operation |
MapLoadAllOperationFactory.createOperation()
|
Operation |
RemoveInterceptorOperationFactory.createOperation()
|
Operation |
PartitionWideEntryOperationFactory.createOperation()
|
Operation |
MapValuesOperationFactory.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 |
AddInterceptorOperationFactory.createOperation()
|
Operation |
MapPutAllOperationFactory.createOperation()
|
Operation |
MultipleEntryOperation.getBackupOperation()
|
Operation |
EvictAllOperation.getBackupOperation()
|
Operation |
BasePutOperation.getBackupOperation()
|
Operation |
PartitionWideEntryWithPredicateOperation.getBackupOperation()
|
Operation |
PartitionWideEntryOperation.getBackupOperation()
|
Operation |
EntryOperation.getBackupOperation()
|
Operation |
MergeOperation.getBackupOperation()
|
Operation |
ClearOperation.getBackupOperation()
|
Operation |
BaseRemoveOperation.getBackupOperation()
|
Operation |
PutAllOperation.getBackupOperation()
|
Operation |
EvictOperation.getBackupOperation()
|
Operation |
PutFromLoadAllOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.map.impl.proxy |
|---|
| Methods in com.hazelcast.map.impl.proxy with parameters of type Operation | |
|---|---|
protected Object |
MapProxyImpl.invoke(Operation operation,
int partitionId)
|
| Uses of Operation in com.hazelcast.map.impl.tx |
|---|
| Subclasses of Operation in com.hazelcast.map.impl.tx | |
|---|---|
class |
TxnDeleteOperation
Transactional delete operation |
class |
TxnLockAndGetOperation
Transactional lock and get operation. |
class |
TxnPrepareBackupOperation
An operation to prepare transaction by locking the key on key backup owner. |
class |
TxnPrepareOperation
An operation to prepare transaction by locking the key on the key owner. |
class |
TxnRollbackBackupOperation
An operation to rollback transaction by unlocking the key on key backup owner. |
class |
TxnRollbackOperation
An operation to rollback transaction by unlocking the key on key owner. |
class |
TxnSetOperation
An operation to unlock and set (key,value) on the partition . |
class |
TxnUnlockBackupOperation
An operation to unlock key on the backup owner. |
class |
TxnUnlockOperation
An operation to unlock key on the partition owner. |
| Methods in com.hazelcast.map.impl.tx that return Operation | |
|---|---|
Operation |
TxnPrepareOperation.getBackupOperation()
|
Operation |
TxnSetOperation.getBackupOperation()
|
Operation |
TxnRollbackOperation.getBackupOperation()
|
Operation |
TxnUnlockOperation.getBackupOperation()
|
Operation |
TxnDeleteOperation.getBackupOperation()
|
| Constructors in com.hazelcast.map.impl.tx with parameters of type Operation | |
|---|---|
MapTransactionLog(String name,
Data key,
Operation op,
long version,
String ownerUuid)
|
|
| Uses of Operation in com.hazelcast.mapreduce.impl |
|---|
| Methods in com.hazelcast.mapreduce.impl with parameters of type Operation | ||
|---|---|---|
static
|
MapReduceUtil.executeOperation(Operation operation,
Address address,
MapReduceService mapReduceService,
NodeEngine nodeEngine)
|
|
| Uses of Operation in com.hazelcast.mapreduce.impl.operation |
|---|
| Subclasses of Operation in com.hazelcast.mapreduce.impl.operation | |
|---|---|
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 |
GetResultOperation
This operation is used to retrieve results from a remote node |
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 |
| Methods in com.hazelcast.mapreduce.impl.operation that return Operation | |
|---|---|
Operation |
GetResultOperationFactory.createOperation()
|
| Uses of Operation in com.hazelcast.multimap.impl |
|---|
| Methods in com.hazelcast.multimap.impl that return Operation | |
|---|---|
Operation |
MultiMapService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.multimap.impl.client |
|---|
| Methods in com.hazelcast.multimap.impl.client that return Operation | |
|---|---|
protected Operation |
KeyBasedContainsRequest.prepareOperation()
|
protected Operation |
CountRequest.prepareOperation()
|
protected Operation |
RemoveRequest.prepareOperation()
|
protected Operation |
PutRequest.prepareOperation()
|
protected Operation |
GetAllRequest.prepareOperation()
|
protected Operation |
RemoveAllRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.multimap.impl.operations |
|---|
| Subclasses of Operation in com.hazelcast.multimap.impl.operations | |
|---|---|
class |
ContainsEntryOperation
|
class |
CountOperation
|
class |
EntrySetOperation
|
class |
KeySetOperation
|
class |
MultiMapBackupAwareOperation
|
class |
MultiMapKeyBasedOperation
|
class |
MultiMapMigrationOperation
|
class |
MultiMapOperation
|
class |
RemoveAllBackupOperation
|
class |
RemoveAllOperation
|
class |
SizeOperation
|
class |
ValuesOperation
|
| Methods in com.hazelcast.multimap.impl.operations that return Operation | |
|---|---|
Operation |
MultiMapOperationFactory.createOperation()
|
Operation |
RemoveAllOperation.getBackupOperation()
|
Operation |
RemoveOperation.getBackupOperation()
|
Operation |
ClearOperation.getBackupOperation()
|
Operation |
PutOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.multimap.impl.txn |
|---|
| Subclasses of Operation in com.hazelcast.multimap.impl.txn | |
|---|---|
class |
TxnCommitBackupOperation
|
class |
TxnCommitOperation
|
class |
TxnGenerateRecordIdOperation
|
class |
TxnPutBackupOperation
|
class |
TxnPutOperation
|
class |
TxnRemoveAllBackupOperation
|
class |
TxnRemoveAllOperation
|
class |
TxnRemoveBackupOperation
|
class |
TxnRemoveOperation
|
| Methods in com.hazelcast.multimap.impl.txn that return Operation | |
|---|---|
Operation |
TxnPrepareOperation.getBackupOperation()
|
Operation |
TxnRollbackOperation.getBackupOperation()
|
Operation |
TxnPutOperation.getBackupOperation()
|
Operation |
TxnRemoveOperation.getBackupOperation()
|
Operation |
TxnCommitOperation.getBackupOperation()
|
Operation |
TxnRemoveAllOperation.getBackupOperation()
|
| Methods in com.hazelcast.multimap.impl.txn with parameters of type Operation | |
|---|---|
void |
MultiMapTransactionLog.addOperation(Operation op)
|
| Constructor parameters in com.hazelcast.multimap.impl.txn with type arguments of type Operation | |
|---|---|
TxnCommitBackupOperation(String name,
Data dataKey,
List<Operation> opList,
String caller,
long threadId)
|
|
TxnCommitOperation(String name,
Data dataKey,
long threadId,
List<Operation> opList)
|
|
| Uses of Operation in com.hazelcast.partition.impl |
|---|
| Subclasses of Operation in com.hazelcast.partition.impl | |
|---|---|
class |
AssignPartitions
|
class |
BaseMigrationOperation
|
class |
CheckReplicaVersion
|
class |
HasOngoingMigration
|
class |
IsReplicaVersionSync
Queries if replica version is sync between partitions. |
class |
MigrationOperation
|
class |
MigrationRequestOperation
|
class |
PartitionStateOperation
|
class |
ReplicaSyncRequest
|
class |
ReplicaSyncResponse
|
class |
ReplicaSyncRetryResponse
|
class |
SafeStateCheckOperation
Checks whether a node is safe or not. |
| Constructor parameters in com.hazelcast.partition.impl with type arguments of type Operation | |
|---|---|
MigrationOperation(MigrationInfo migrationInfo,
long[] replicaVersions,
Collection<Operation> tasks)
|
|
ReplicaSyncResponse(List<Operation> data,
long[] replicaVersions)
|
|
| Uses of Operation in com.hazelcast.queue.impl |
|---|
| Methods in com.hazelcast.queue.impl that return Operation | |
|---|---|
Operation |
QueueService.prepareReplicationOperation(PartitionReplicationEvent event)
|
| Uses of Operation in com.hazelcast.queue.impl.client |
|---|
| Methods in com.hazelcast.queue.impl.client that return Operation | |
|---|---|
protected Operation |
DrainRequest.prepareOperation()
|
protected Operation |
OfferRequest.prepareOperation()
|
protected Operation |
AddAllRequest.prepareOperation()
|
protected Operation |
RemoveRequest.prepareOperation()
|
protected Operation |
RemainingCapacityRequest.prepareOperation()
|
protected Operation |
CompareAndRemoveRequest.prepareOperation()
|
protected Operation |
IteratorRequest.prepareOperation()
|
protected Operation |
ClearRequest.prepareOperation()
|
protected Operation |
PollRequest.prepareOperation()
|
protected Operation |
PeekRequest.prepareOperation()
|
protected Operation |
ContainsRequest.prepareOperation()
|
protected Operation |
SizeRequest.prepareOperation()
|
protected Operation |
IsEmptyRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.queue.impl.operations |
|---|
| Subclasses of Operation in com.hazelcast.queue.impl.operations | |
|---|---|
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 |
IsEmptyOperation
check if queue is empty |
class |
IteratorOperation
Provides iterator functionality for Queue. |
class |
OfferBackupOperation
Backup items during offer operation. |
class |
OfferOperation
Contains offer operation for the Queue. |
class |
PeekOperation
Peek operation for Queue. |
class |
PollBackupOperation
Backup items during pool operation. |
class |
PollOperation
Pool operation for Queue. |
class |
QueueBackupAwareOperation
This abstract class contains important methods for all Queue operations. |
class |
QueueOperation
This class contains methods for Queue operations such as AddAllOperation. |
class |
QueueReplicationOperation
Replication operation for the Queue. |
class |
RemainingCapacityOperation
Returns the remaining capacity of the queue based on config max-size |
| Methods in com.hazelcast.queue.impl.operations that return Operation | |
|---|---|
Operation |
PollOperation.getBackupOperation()
|
Operation |
OfferOperation.getBackupOperation()
|
Operation |
RemoveOperation.getBackupOperation()
|
Operation |
AddAllOperation.getBackupOperation()
|
Operation |
ClearOperation.getBackupOperation()
|
Operation |
CompareAndRemoveOperation.getBackupOperation()
|
Operation |
DrainOperation.getBackupOperation()
|
| Uses of Operation in com.hazelcast.queue.impl.tx |
|---|
| Subclasses of Operation in com.hazelcast.queue.impl.tx | |
|---|---|
class |
QueueTransactionRollbackOperation
Transaction Rollback Operation for the Queue. |
class |
TxnOfferBackupOperation
Provides backup operation during transactional offer operation. |
class |
TxnOfferOperation
Offer operation for the Transactional Queue. |
class |
TxnPeekOperation
Peek operation for the transactional queue. |
class |
TxnPollBackupOperation
Provides backup operation during transactional poll operation. |
class |
TxnPollOperation
Poll operation for the transactional queue. |
class |
TxnReserveOfferBackupOperation
Reserve offer backup operation for the transactional queue. |
class |
TxnReserveOfferOperation
Reserve offer operation for the transactional queue. |
class |
TxnReservePollBackupOperation
Reserve poll backup operation for the transactional queue. |
class |
TxnReservePollOperation
Reserve poll operation for the transactional queue. |
| Methods in com.hazelcast.queue.impl.tx that return Operation | |
|---|---|
Operation |
TxnPrepareOperation.getBackupOperation()
|
Operation |
TxnRollbackOperation.getBackupOperation()
|
Operation |
TxnOfferOperation.getBackupOperation()
|
Operation |
TxnReserveOfferOperation.getBackupOperation()
|
Operation |
TxnPollOperation.getBackupOperation()
|
Operation |
TxnReservePollOperation.getBackupOperation()
|
| Constructors in com.hazelcast.queue.impl.tx with parameters of type Operation | |
|---|---|
QueueTransactionLog(String transactionId,
long itemId,
String name,
int partitionId,
Operation op)
|
|
| Uses of Operation in com.hazelcast.replicatedmap.impl.operation |
|---|
| Subclasses of Operation in com.hazelcast.replicatedmap.impl.operation | |
|---|---|
class |
AbstractReplicatedMapOperation
Base class for replicated map remote operations |
class |
ReplicatedMapClearOperation
This operation will execute the remote clear on replicated map if ReplicatedMap.clear() is called. |
class |
ReplicatedMapInitChunkOperation
Class for requesting an initial chunk of data from another node to pre-provision newly joining members |
class |
ReplicatedMapPostJoinOperation
The replicated map post join operation to execute on remote nodes |
| Uses of Operation in com.hazelcast.spi |
|---|
| Subclasses of Operation in com.hazelcast.spi | |
|---|---|
class |
AbstractOperation
Abstract Operation implementation with some basic methods
implemented. |
| Fields in com.hazelcast.spi declared as Operation | |
|---|---|
protected Operation |
InvocationBuilder.op
|
| Methods in com.hazelcast.spi that return Operation | |
|---|---|
Operation |
OperationFactory.createOperation()
Creates the operation. |
Operation |
BackupAwareOperation.getBackupOperation()
Creates the BackupOperation responsible for making the backup. |
Operation |
InvocationBuilder.getOp()
|
Operation |
PostJoinAwareService.getPostJoinOperation()
Post join operations must be lock free; means no locks at all; no partition locks, no key-based locks, no service level locks or no database interaction! |
Operation |
MigrationAwareService.prepareReplicationOperation(PartitionReplicationEvent event)
|
Operation |
Operation.setCallerUuid(String callerUuid)
|
Operation |
Operation.setNodeEngine(NodeEngine nodeEngine)
|
Operation |
Operation.setPartitionId(int partitionId)
|
Operation |
Operation.setReplicaIndex(int replicaIndex)
|
Operation |
Operation.setResponseHandler(ResponseHandler responseHandler)
|
Operation |
Operation.setService(Object service)
|
Operation |
Operation.setServiceName(String serviceName)
|
Operation |
Operation.setValidateTarget(boolean validateTarget)
|
| Methods in com.hazelcast.spi with parameters of type Operation | ||
|---|---|---|
InvocationBuilder |
OperationService.createInvocationBuilder(String serviceName,
Operation op,
Address target)
|
|
InvocationBuilder |
OperationService.createInvocationBuilder(String serviceName,
Operation op,
int partitionId)
|
|
void |
OperationService.executeOperation(Operation op)
Executes operation in operation executor pool. |
|
|
OperationService.invokeOnPartition(String serviceName,
Operation op,
int partitionId)
|
|
|
OperationService.invokeOnTarget(String serviceName,
Operation op,
Address target)
|
|
boolean |
OperationService.isAllowedToRunOnCallingThread(Operation op)
Returns true if given operation is allowed to run on calling thread, false otherwise. |
|
static boolean |
OperationAccessor.isJoinOperation(Operation op)
|
|
static boolean |
OperationAccessor.isMigrationOperation(Operation op)
|
|
void |
OperationService.runOperationOnCallingThread(Operation op)
Runs operation in 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)
|
|
static void |
OperationAccessor.setCallTimeout(Operation op,
long callTimeout)
|
|
static void |
OperationAccessor.setConnection(Operation op,
Connection connection)
|
|
static void |
OperationAccessor.setInvocationTime(Operation op,
long invocationTime)
|
|
| Constructors in com.hazelcast.spi with parameters of type Operation | |
|---|---|
InvocationBuilder(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
int partitionId,
Address target)
Creates an InvocationBuilder |
|
| Uses of Operation in com.hazelcast.spi.impl |
|---|
| Subclasses of Operation in com.hazelcast.spi.impl | |
|---|---|
class |
AbstractNamedOperation
|
static class |
EventServiceImpl.DeregistrationOperation
|
static class |
EventServiceImpl.PostJoinRegistrationOperation
|
static class |
EventServiceImpl.RegistrationOperation
|
static class |
EventServiceImpl.SendEventOperation
|
class |
IsStillExecutingOperation
An operation that checks if another operation is still running. |
class |
PartitionIteratingOperation
|
static class |
ProxyServiceImpl.DistributedObjectDestroyOperation
|
static class |
ProxyServiceImpl.PostJoinProxyOperation
|
class |
TraceableIsStillExecutingOperation
|
| Methods in com.hazelcast.spi.impl that return Operation | |
|---|---|
Operation |
BinaryOperationFactory.createOperation()
|
Operation |
ProxyServiceImpl.getPostJoinOperation()
|
Operation[] |
NodeEngineImpl.getPostJoinOperations()
Post join operations must be lock free; means no locks at all; no partition locks, no key-based locks, no service level locks! Post join operations should return response, at least a null response. |
| Methods in com.hazelcast.spi.impl with parameters of type Operation | |
|---|---|
void |
BasicOperationScheduler.execute(Operation op)
|
boolean |
BasicBackPressureService.isBackPressureNeeded(Operation op)
Checks if back pressure is needed. |
boolean |
InternalOperationService.isCallTimedOut(Operation op)
|
| Constructors in com.hazelcast.spi.impl with parameters of type Operation | |
|---|---|
BasicInvocationBuilder(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
Address target)
|
|
BasicInvocationBuilder(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
int partitionId)
|
|
BasicPartitionInvocation(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
int partitionId,
int replicaIndex,
int tryCount,
long tryPauseMillis,
long callTimeout,
Callback<Object> callback,
String executorName,
boolean resultDeserialized)
|
|
BasicTargetInvocation(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
Address target,
int tryCount,
long tryPauseMillis,
long callTimeout,
Callback<Object> callback,
String executorName,
boolean resultDeserialized)
|
|
BinaryOperationFactory(Operation operation,
NodeEngine nodeEngine)
|
|
| Uses of Operation in com.hazelcast.topic.impl |
|---|
| Subclasses of Operation in com.hazelcast.topic.impl | |
|---|---|
class |
PublishOperation
|
| Uses of Operation in com.hazelcast.topic.impl.client |
|---|
| Methods in com.hazelcast.topic.impl.client that return Operation | |
|---|---|
protected Operation |
PublishRequest.prepareOperation()
|
| Uses of Operation in com.hazelcast.transaction.impl |
|---|
| Subclasses of Operation in com.hazelcast.transaction.impl | |
|---|---|
class |
BeginTxBackupOperation
|
class |
BroadcastTxRollbackOperation
|
class |
PurgeTxBackupOperation
|
class |
RecoverTxnOperation
|
class |
ReplicateTxOperation
|
class |
RollbackTxBackupOperation
|
|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||