Package | Description |
---|---|
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 | |
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMutatingCacheOperation
Base class for all mutable cache operations.
|
class |
CacheBackupEntryProcessorOperation
Operation of the Cache Backup Entry Processor.
|
class |
CacheClearBackupOperation
Backup operation of
CacheClearOperation . |
class |
CacheClearOperation
Cache Clear will clear all internal cache data without sending any event
|
class |
CacheContainsKeyOperation
Cache contains key operation, determines if the cache contains an entry for the specified key.
|
class |
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.
|
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Method and Description |
---|---|
Operation |
ClientEngineImpl.getPostJoinOperation() |
Modifier and Type | Method and Description |
---|---|
protected abstract Operation |
PartitionClientRequest.prepareOperation() |
protected abstract Operation |
TargetClientRequest.prepareOperation() |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
InvocationClientRequest.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
protected InvocationBuilder |
InvocationClientRequest.createInvocationBuilder(String serviceName,
Operation op,
int partitionId) |
Modifier and Type | Class and Description |
---|---|
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
PostJoinClientOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
OperationFactoryWrapper.createOperation() |
Modifier and Type | Class and Description |
---|---|
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 |
Constructor and Description |
---|
PostJoinOperation(Operation... ops) |
Modifier and Type | Class and Description |
---|---|
class |
CollectionAddAllBackupOperation |
class |
CollectionAddAllOperation |
class |
CollectionAddBackupOperation |
class |
CollectionAddOperation |
class |
CollectionBackupAwareOperation |
class |
CollectionClearBackupOperation |
class |
CollectionClearOperation |
class |
CollectionCompareAndRemoveOperation |
class |
CollectionContainsOperation |
class |
CollectionGetAllOperation |
class |
CollectionIsEmptyOperation |
class |
CollectionOperation |
class |
CollectionRemoveBackupOperation |
class |
CollectionRemoveOperation |
class |
CollectionReplicationOperation |
class |
CollectionSizeOperation |
class |
CollectionTransactionRollbackOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
CollectionCompareAndRemoveOperation.getBackupOperation() |
Operation |
CollectionAddAllOperation.getBackupOperation() |
Operation |
CollectionRemoveOperation.getBackupOperation() |
Operation |
CollectionClearOperation.getBackupOperation() |
Operation |
CollectionAddOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
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() |
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() |
Operation |
ListService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
SetReplicationOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
SetService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Class and Description |
---|---|
class |
CollectionPrepareBackupOperation |
class |
CollectionPrepareOperation |
class |
CollectionReserveAddOperation |
class |
CollectionReserveRemoveOperation |
class |
CollectionRollbackBackupOperation |
class |
CollectionRollbackOperation |
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() |
Constructor and Description |
---|
CollectionTransactionLog(long itemId,
String name,
int partitionId,
String serviceName,
String transactionId,
Operation op) |
Modifier and Type | Method and Description |
---|---|
Operation |
AtomicLongService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Class and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
Operation |
SetOperation.getBackupOperation() |
Operation |
GetAndSetOperation.getBackupOperation() |
Operation |
AbstractAlterOperation.getBackupOperation() |
Operation |
CompareAndSetOperation.getBackupOperation() |
Operation |
AddAndGetOperation.getBackupOperation() |
Operation |
GetAndAddOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
AtomicReferenceService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Class and Description |
---|---|
class |
AtomicReferenceBackupAwareOperation |
class |
AtomicReferenceBaseOperation |
class |
AtomicReferenceReplicationOperation |
class |
ContainsOperation |
class |
IsNullOperation |
class |
SetAndGetOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
SetOperation.getBackupOperation() |
Operation |
GetAndSetOperation.getBackupOperation() |
Operation |
AbstractAlterOperation.getBackupOperation() |
Operation |
SetAndGetOperation.getBackupOperation() |
Operation |
CompareAndSetOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
CountDownLatchService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
SetCountRequest.prepareOperation() |
protected Operation |
CountDownRequest.prepareOperation() |
protected Operation |
AwaitRequest.prepareOperation() |
protected Operation |
GetCountRequest.prepareOperation() |
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) |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Class and Description |
---|---|
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 | Method and Description |
---|---|
protected Operation |
DrainRequest.prepareOperation() |
protected Operation |
ReleaseRequest.prepareOperation() |
protected Operation |
InitRequest.prepareOperation() |
protected Operation |
AcquireRequest.prepareOperation() |
protected Operation |
ReduceRequest.prepareOperation() |
protected Operation |
AvailableRequest.prepareOperation() |
Modifier and Type | Class and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
Operation |
SemaphoreDeadMemberOperation.getBackupOperation() |
Operation |
InitOperation.getBackupOperation() |
Operation |
ReleaseOperation.getBackupOperation() |
Operation |
ReduceOperation.getBackupOperation() |
Operation |
AcquireOperation.getBackupOperation() |
Operation |
DrainOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
protected Operation |
PartitionCallableRequest.prepareOperation() |
protected Operation |
TargetCallableRequest.prepareOperation() |
Modifier and Type | Class and Description |
---|---|
class |
CallableTaskOperation |
class |
CancellationOperation |
class |
MemberCallableTaskOperation |
class |
ShutdownOperation |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Class and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
Operation |
MapService.getPostJoinOperation() |
Operation |
MapService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Method and Description |
---|---|
protected Object |
MapProxyImpl.invoke(Operation operation,
int partitionId) |
Modifier and Type | Class and Description |
---|---|
class |
TxnDeleteOperation
Transactional delete operation
|
class |
TxnLockAndGetOperation
Transactional lock and get operation.
|
class |
TxnPrepareBackupOperation
An operation to prepare transaction by locking the key on key backup owner.
|
class |
TxnPrepareOperation
An operation to prepare transaction by locking the key on the key owner.
|
class |
TxnRollbackBackupOperation
An operation to rollback transaction by unlocking the key on key backup owner.
|
class |
TxnRollbackOperation
An operation to rollback transaction by unlocking the key on key owner.
|
class |
TxnSetOperation
An operation to unlock and set (key,value) on the partition .
|
class |
TxnUnlockBackupOperation
An operation to unlock key on the backup owner.
|
class |
TxnUnlockOperation
An operation to unlock key on the partition owner.
|
Modifier and Type | Method and Description |
---|---|
Operation |
TxnPrepareOperation.getBackupOperation() |
Operation |
TxnSetOperation.getBackupOperation() |
Operation |
TxnRollbackOperation.getBackupOperation() |
Operation |
TxnUnlockOperation.getBackupOperation() |
Operation |
TxnDeleteOperation.getBackupOperation() |
Constructor and Description |
---|
MapTransactionLog(String name,
Data key,
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 |
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
|
Modifier and Type | Method and Description |
---|---|
Operation |
GetResultOperationFactory.createOperation() |
Modifier and Type | Method and Description |
---|---|
Operation |
MultiMapService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
protected Operation |
KeyBasedContainsRequest.prepareOperation() |
protected Operation |
CountRequest.prepareOperation() |
protected Operation |
RemoveRequest.prepareOperation() |
protected Operation |
PutRequest.prepareOperation() |
protected Operation |
GetAllRequest.prepareOperation() |
protected Operation |
RemoveAllRequest.prepareOperation() |
Modifier and Type | Class and Description |
---|---|
class |
ContainsEntryOperation |
class |
CountOperation |
class |
EntrySetOperation |
class |
KeySetOperation |
class |
MultiMapBackupAwareOperation |
class |
MultiMapKeyBasedOperation |
class |
MultiMapMigrationOperation |
class |
MultiMapOperation |
class |
RemoveAllBackupOperation |
class |
RemoveAllOperation |
class |
SizeOperation |
class |
ValuesOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
MultiMapOperationFactory.createOperation() |
Operation |
RemoveAllOperation.getBackupOperation() |
Operation |
RemoveOperation.getBackupOperation() |
Operation |
ClearOperation.getBackupOperation() |
Operation |
PutOperation.getBackupOperation() |
Modifier and Type | Class and Description |
---|---|
class |
TxnCommitBackupOperation |
class |
TxnCommitOperation |
class |
TxnGenerateRecordIdOperation |
class |
TxnPutBackupOperation |
class |
TxnPutOperation |
class |
TxnRemoveAllBackupOperation |
class |
TxnRemoveAllOperation |
class |
TxnRemoveBackupOperation |
class |
TxnRemoveOperation |
Modifier and Type | Method and Description |
---|---|
Operation |
TxnPrepareOperation.getBackupOperation() |
Operation |
TxnRollbackOperation.getBackupOperation() |
Operation |
TxnPutOperation.getBackupOperation() |
Operation |
TxnRemoveOperation.getBackupOperation() |
Operation |
TxnCommitOperation.getBackupOperation() |
Operation |
TxnRemoveAllOperation.getBackupOperation() |
Modifier and Type | Method and Description |
---|---|
void |
MultiMapTransactionLog.addOperation(Operation op) |
Constructor and Description |
---|
TxnCommitBackupOperation(String name,
Data dataKey,
List<Operation> opList,
String caller,
long threadId) |
TxnCommitOperation(String name,
Data dataKey,
long threadId,
List<Operation> opList) |
Modifier and Type | Class and Description |
---|---|
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 and Description |
---|
MigrationOperation(MigrationInfo migrationInfo,
long[] replicaVersions,
Collection<Operation> tasks) |
ReplicaSyncResponse(List<Operation> data,
long[] replicaVersions) |
Modifier and Type | Method and Description |
---|---|
Operation |
QueueService.prepareReplicationOperation(PartitionReplicationEvent event) |
Modifier and Type | Method and Description |
---|---|
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() |
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 |
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
|
Modifier and Type | Method and Description |
---|---|
Operation |
PollOperation.getBackupOperation() |
Operation |
OfferOperation.getBackupOperation() |
Operation |
RemoveOperation.getBackupOperation() |
Operation |
AddAllOperation.getBackupOperation() |
Operation |
ClearOperation.getBackupOperation() |
Operation |
CompareAndRemoveOperation.getBackupOperation() |
Operation |
DrainOperation.getBackupOperation() |
Modifier and Type | Class and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
Operation |
TxnPrepareOperation.getBackupOperation() |
Operation |
TxnRollbackOperation.getBackupOperation() |
Operation |
TxnOfferOperation.getBackupOperation() |
Operation |
TxnReserveOfferOperation.getBackupOperation() |
Operation |
TxnPollOperation.getBackupOperation() |
Operation |
TxnReservePollOperation.getBackupOperation() |
Constructor and Description |
---|
QueueTransactionLog(String transactionId,
long itemId,
String name,
int partitionId,
Operation op) |
Modifier and Type | Class and Description |
---|---|
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
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractOperation
Abstract
Operation implementation with some basic methods
implemented. |
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() |
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) |
Modifier and Type | Method and Description |
---|---|
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.
|
<E> InternalCompletableFuture<E> |
OperationService.invokeOnPartition(String serviceName,
Operation op,
int partitionId) |
<E> InternalCompletableFuture<E> |
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) |
Constructor and Description |
---|
InvocationBuilder(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
int partitionId,
Address target)
Creates an InvocationBuilder
|
Modifier and Type | Class and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
void |
BasicOperationScheduler.execute(Operation op) |
boolean |
BasicBackPressureService.isBackPressureNeeded(Operation op)
Checks if back pressure is needed.
|
boolean |
InternalOperationService.isCallTimedOut(Operation op) |
Constructor and Description |
---|
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) |
Modifier and Type | Class and Description |
---|---|
class |
PublishOperation |
Modifier and Type | Method and Description |
---|---|
protected Operation |
PublishRequest.prepareOperation() |
Modifier and Type | Class and Description |
---|---|
class |
BeginTxBackupOperation |
class |
BroadcastTxRollbackOperation |
class |
PurgeTxBackupOperation |
class |
RecoverTxnOperation |
class |
ReplicateTxOperation |
class |
RollbackTxBackupOperation |
Copyright © 2014 Hazelcast, Inc.. All Rights Reserved.