Package | Description |
---|---|
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
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.impl.collection.operations | |
com.hazelcast.collection.impl.list.operations | |
com.hazelcast.collection.impl.queue.operations |
This package contains the IQueue operations
|
com.hazelcast.collection.impl.set.operations | |
com.hazelcast.concurrent.atomiclong.operations |
This package contains the operations on the IAtomicLong.
|
com.hazelcast.concurrent.atomicreference.operations |
This package contains the operations on the IAtomicReference.
|
com.hazelcast.concurrent.countdownlatch.operations |
This package contains the operations on the ICountDownLatch.
|
com.hazelcast.concurrent.lock.operations |
This package contains the operations on the ILock.
|
com.hazelcast.concurrent.semaphore.operations |
This package contains the operations on the ISemaphore.
|
com.hazelcast.executor.impl.operations |
This package contains operations for the IExecutorService.
|
com.hazelcast.internal.management.operation |
Contains operations that are called from Management Center.
|
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.query | |
com.hazelcast.map.impl.tx |
Contains implementation classes for
TransactionalMap |
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.operations |
Contains operations for Hazelcast MultiMap module.
|
com.hazelcast.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.replicatedmap.impl.operation |
This package contains replicated map operations which are executed on remote nodes
|
com.hazelcast.ringbuffer.impl.operations | |
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.eventservice.impl.operations |
Contains the operations for the
EventServiceImpl . |
com.hazelcast.spi.impl.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.spi.impl.proxyservice.impl.operations |
Contains the operations for the
ProxyServiceImpl . |
com.hazelcast.topic.impl |
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
com.hazelcast.transaction.impl.operations | |
com.hazelcast.transaction.impl.xa.operations |
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
CacheService#deleteCache(String, boolean, String, boolean) . |
class |
CacheEntryProcessorOperation
Operation of the Cache Entry Processor.
|
class |
CacheGetAllOperation
Gets all keys from the cache.
|
class |
CacheGetAndRemoveOperation
Cache GetAndRemove Operation.
|
class |
CacheGetAndReplaceOperation
Cache GetAndReplace Operation.
|
class |
CacheGetConfigOperation
Cache GetConfig Operation.
|
class |
CacheGetOperation
Cache Get Operation.
|
class |
CacheKeyIteratorOperation
Provides iterator functionality for ICache.
|
class |
CacheListenerRegistrationOperation
Listener can be registered and unregistered by
CacheService . |
class |
CacheLoadAllOperation
Loads all entries of the keys to partition record store
ICacheRecordStore . |
class |
CacheManagementConfigOperation
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and
statistics mxbeans of the cache.
|
class |
CacheMergeOperation |
class |
CachePutAllBackupOperation
Cache PutAllBackup Operation is the backup operation used by load all operation.
|
class |
CachePutAllOperation |
class |
CachePutBackupOperation
Backup operation for the operation of adding cache entries into record stores.
|
class |
CachePutIfAbsentOperation
Operation implementation for calling
ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int) . |
class |
CachePutOperation
Operation implementation for
ICacheRecordStore.put(Data, Object, ExpiryPolicy, String, int) and
ICacheRecordStore.getAndPut(Data, Object, ExpiryPolicy, String, int) . |
class |
CacheRemoveAllBackupOperation
Backup operation of
CacheRemoveAllOperation . |
class |
CacheRemoveAllOperation
TODO add a proper JavaDoc
|
class |
CacheRemoveBackupOperation
Backup operation used by remove operations.
|
class |
CacheRemoveOperation
Operation implementation for cache remove functionality.
|
class |
CacheReplaceOperation
Operator implementation for cache replace functionality.
|
class |
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.
|
class |
PostJoinCacheOperation |
Modifier and Type | Class and Description |
---|---|
class |
ClientDisconnectionOperation |
class |
ClientReAuthOperation |
class |
GetConnectedClientsOperation |
class |
PostJoinClientOperation |
Modifier and Type | Class and Description |
---|---|
class |
AuthenticationFailureOperation |
class |
AuthorizationOperation |
class |
BeforeJoinCheckFailureOperation |
class |
ChangeClusterStateOperation |
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 |
LockClusterStateOperation |
class |
MasterClaimOperation |
class |
MasterConfirmationOperation |
class |
MasterDiscoveryOperation |
class |
MemberAttributeChangedOperation |
class |
MemberInfoUpdateOperation |
class |
MemberRemoveOperation |
class |
MergeClustersOperation |
class |
PostJoinOperation |
class |
RollbackClusterStateOperation |
class |
SetMasterOperation |
class |
ShutdownNodeOperation |
class |
TriggerMemberListPublishOperation
Requests member list publish from master node
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
ListReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
QueueReplicationOperation
Replication operation for the Queue.
|
Modifier and Type | Class and Description |
---|---|
class |
SetReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AtomicLongReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AtomicReferenceReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AwaitOperation |
class |
CountDownLatchBackupOperation |
class |
CountDownLatchReplicationOperation |
class |
CountDownOperation |
class |
GetCountOperation |
class |
SetCountOperation |
Modifier and Type | Class and Description |
---|---|
class |
AwaitBackupOperation |
class |
BaseLockOperation |
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 | 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 | Class and Description |
---|---|
class |
ShutdownOperation |
Modifier and Type | Class and Description |
---|---|
class |
ChangeWanStateOperation
Enables/Disable publishing events to target cluster in WAN Replication
WanReplicationService
on a node. |
Modifier and Type | Class and Description |
---|---|
class |
QueryOperation |
class |
QueryPartitionOperation |
Modifier and Type | Class and Description |
---|---|
class |
TxnDeleteOperation
Transactional delete operation
|
class |
TxnLockAndGetOperation
Transactional lock and get operation.
|
class |
TxnPrepareBackupOperation
An operation to prepare transaction by locking the key on key backup owner.
|
class |
TxnPrepareOperation
An operation to prepare transaction by locking the key on the key owner.
|
class |
TxnRollbackBackupOperation
An operation to rollback transaction by unlocking the key on key backup owner.
|
class |
TxnRollbackOperation
An operation to rollback transaction by unlocking the key on key owner.
|
class |
TxnSetOperation
An operation to unlock and set (key,value) on the partition .
|
class |
TxnUnlockBackupOperation
An operation to unlock key on the backup owner.
|
class |
TxnUnlockOperation
An operation to unlock key on the partition owner.
|
Modifier and Type | Class and Description |
---|---|
class |
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 | Class and Description |
---|---|
class |
MultiMapMigrationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AssignPartitions |
class |
BaseMigrationOperation |
class |
HasOngoingMigration |
class |
MigrationOperation |
class |
MigrationRequestOperation |
class |
PartitionStateOperation |
class |
SafeStateCheckOperation
Checks whether a node is safe or not.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractReplicatedMapOperation |
class |
CheckReplicaVersion
Checks whether replica version is in sync with the primary.
|
class |
ClearOperation
This operation will execute the remote clear on replicated map if
ReplicatedMap.clear() is called. |
class |
ContainsKeyOperation |
class |
ContainsValueOperation |
class |
EntrySetOperation |
class |
EvictionOperation
Evicts set of entries from the record store.
|
class |
GetOperation |
class |
IsEmptyOperation |
class |
KeySetOperation |
class |
PutAllOperation
Puts a set of records to the replicated map.
|
class |
ReplicateUpdateOperation
Replicates the update happened on the partition owner to the other nodes.
|
class |
ReplicateUpdateToCallerOperation
This operation will update the local record store with the update received from local/remote partition owner.
|
class |
RequestMapDataOperation
Collects and sends the replicated map data from the executing node to the caller via
SyncReplicatedMapDataOperation . |
class |
SizeOperation |
class |
SyncReplicatedMapDataOperation<K,V>
Carries set of replicated map records for a partition from one node to another
|
class |
ValuesOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRingBufferOperation |
class |
AddAllBackupOperation |
class |
AddAllOperation |
class |
AddBackupOperation |
class |
AddOperation |
class |
GenericOperation |
class |
ReadManyOperation |
class |
ReadOneOperation |
class |
ReplicationOperation |
Modifier and Type | Class and Description |
---|---|
class |
AbstractNamedOperation |
Modifier and Type | Class and Description |
---|---|
class |
DeregistrationOperation |
class |
PostJoinRegistrationOperation |
class |
RegistrationOperation |
class |
SendEventOperation |
Modifier and Type | Class and Description |
---|---|
class |
IsStillExecutingOperation
An operation that checks if another operation is still running.
|
class |
PartitionIteratingOperation |
class |
TraceableIsStillExecutingOperation |
Modifier and Type | Class and Description |
---|---|
class |
DistributedObjectDestroyOperation |
class |
InitializeDistributedObjectOperation |
class |
PostJoinProxyOperation |
Modifier and Type | Class and Description |
---|---|
class |
PublishOperation |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastTxRollbackOperation |
class |
CreateAllowedDuringPassiveStateTxBackupLogOperation |
class |
CreateTxBackupLogOperation |
class |
PurgeAllowedDuringPassiveStateTxBackupLogOperation |
class |
PurgeTxBackupLogOperation |
class |
ReplicateAllowedDuringPassiveStateTxBackupLogOperation |
class |
ReplicateTxBackupLogOperation
Replicates the transactionlog to a remote system.
|
class |
RollbackAllowedDuringPassiveStateTxBackupLogOperation |
class |
RollbackTxBackupLogOperation |
class |
TxBaseOperation |
Modifier and Type | Class and Description |
---|---|
class |
BaseXAOperation |
class |
ClearRemoteTransactionBackupOperation |
class |
ClearRemoteTransactionOperation |
class |
CollectRemoteTransactionsOperation |
class |
FinalizeRemoteTransactionBackupOperation |
class |
FinalizeRemoteTransactionOperation |
class |
PutRemoteTransactionBackupOperation |
class |
PutRemoteTransactionOperation |
class |
XaReplicationOperation |
Copyright © 2016 Hazelcast, Inc.. All Rights Reserved.