| 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 | This package contains classes related to Collections (IList,ISet etc..)  | 
| com.hazelcast.collection.list | This package contains IList functionality for Hazelcast. | 
| com.hazelcast.collection.set | This package contains ISet functionality for Hazelcast. | 
| 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.map.impl.operation | Package for map operations. | 
| 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.queue.impl.operations | This package contains the IQueue operations | 
| com.hazelcast.replicatedmap.impl.operation | This package contains some remote operations to execute on remote nodes | 
| 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. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMutatingCacheOperationBase class for all mutable cache operations. | 
| class  | CacheBackupEntryProcessorOperationOperation of the Cache Backup Entry Processor. | 
| class  | CacheClearBackupOperationBackup operation of  CacheClearOperation. | 
| class  | CacheClearOperationCache Clear will clear all internal cache data without sending any event | 
| class  | CacheContainsKeyOperationCache contains key operation, determines if the cache contains an entry for the specified key. | 
| class  | CacheCreateConfigOperationUsed to create cluster wide cache configuration. | 
| class  | CacheDestroyOperationDestroys the cache on the cluster or on a single node by calling
  AbstractCacheService.destroyCache(String, boolean, String). | 
| class  | CacheEntryProcessorOperationOperation of the Cache Entry Processor. | 
| class  | CacheGetAllOperationGets all keys from the cache. | 
| class  | CacheGetAndRemoveOperationCache GetAndRemove Operation. | 
| class  | CacheGetAndReplaceOperationCache GetAndReplace Operation. | 
| class  | CacheGetConfigOperationCache GetConfig Operation. | 
| class  | CacheGetOperationCache Get Operation. | 
| class  | CacheKeyIteratorOperationProvides iterator functionality for ICache. | 
| class  | CacheListenerRegistrationOperationListener can be registered and unregistered by  CacheService. | 
| class  | CacheLoadAllOperationLoads all entries of the keys to partition record store  ICacheRecordStore. | 
| class  | CacheManagementConfigOperationCache ManagementConfig Operation provides enabling/disabling the functionality of  management and
 statistics mxbeans of the cache. | 
| class  | CachePutAllBackupOperationCache PutAllBackup Operation is the backup operation used by load all operation. | 
| class  | CachePutBackupOperationBackup operation for the operation of adding cache entries into record stores. | 
| class  | CachePutIfAbsentOperationOperation implementation for calling
  ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int). | 
| class  | CachePutOperationOperation implementation for
  com.hazelcast.cache.impl.ICacheRecordStore#put(Data, Object, ExpiryPolicy, String)andcom.hazelcast.cache.impl.ICacheRecordStore#getAndPut(Data, Object, ExpiryPolicy, String). | 
| class  | CacheRemoveAllBackupOperationBackup operation of  CacheRemoveAllOperation. | 
| class  | CacheRemoveAllOperationTODO add a proper JavaDoc | 
| class  | CacheRemoveBackupOperationBackup operation used by remove operations. | 
| class  | CacheRemoveOperationOperation implementation for cache remove functionality. | 
| class  | CacheReplaceOperationOperator implementation for cache replace functionality. | 
| class  | CacheReplicationOperationReplication operation is the data migration operation of  CacheRecordStore. | 
| class  | CacheSizeOperationThis 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  | PostJoinClientOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AuthenticationFailureOperation | 
| class  | AuthorizationOperation | 
| class  | ConfigMismatchOperationWhen 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 | 
| class  | TriggerMemberListPublishOperationRequests 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  | SetReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AtomicLongReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AtomicReferenceReplicationOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CountDownLatchBackupOperation | 
| class  | CountDownLatchReplicationOperation | 
| class  | CountDownOperation | 
| class  | GetCountOperation | 
| class  | SetCountOperation | 
| 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 | 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  | CancelJobSupervisorOperationThis operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes. | 
| class  | FireNotificationOperationThis 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  | GetResultOperationThis operation is used to retrieve results from a remote node | 
| class  | KeysAssignmentOperationThis operation is used to request assignment for keys on the job owners node. | 
| class  | KeyValueJobOperation<K,V>This operation is used to prepare a  KeyValueSourcebased
 map reduce operation on all cluster members. | 
| class  | NotifyRemoteExceptionOperationThis operation is used to inform the job owner of a remote exception | 
| class  | PostPonePartitionProcessingThis operation is used to tell the job owner to postpone a mapping phase for the defined
 partitionId. | 
| class  | ProcessingOperationThis is the base class for all map reduce framework operations, it always contains the name of
 the JobTracker and the unique jobId | 
| class  | ProcessStatsUpdateOperationThis operation is used to update the process statistics on the owner node | 
| class  | RequestMemberIdAssignmentThis operation is used to do some kind of partitionId based processing on non partition based implementations
 of  KeyValueSource(not implementingPartitionIdAware)
 which can happen for custom data sources like distributed filesystems that are up to the end user on how to
 manage the distribution. | 
| class  | RequestPartitionMappingThis operation requests a new partition to process by the requester on the job owning node | 
| class  | RequestPartitionProcessedThis operation tells the job owner to mark a partition as fully processed | 
| class  | RequestPartitionReducingThis 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  | SafeStateCheckOperationChecks whether a node is safe or not. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueueReplicationOperationReplication operation for the Queue. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReplicatedMapClearOperationThis operation will execute the remote clear on replicated map if
  ReplicatedMap.clear()is called. | 
| 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  | IsStillExecutingOperationAn operation that checks if another operation is still running. | 
| class  | PartitionIteratingOperation | 
| static class  | ProxyServiceImpl.DistributedObjectDestroyOperation | 
| static class  | ProxyServiceImpl.PostJoinProxyOperation | 
| class  | TraceableIsStillExecutingOperation | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PublishOperation | 
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.