Uses of Class
com.hazelcast.spi.AbstractOperation

Packages that use AbstractOperation
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. 
 

Uses of AbstractOperation in com.hazelcast.cache.impl.operation
 

Subclasses of AbstractOperation 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.
 

Uses of AbstractOperation in com.hazelcast.client.impl.operations
 

Subclasses of AbstractOperation in com.hazelcast.client.impl.operations
 class ClientDisconnectionOperation
           
 class ClientReAuthOperation
           
 class PostJoinClientOperation
           
 

Uses of AbstractOperation in com.hazelcast.cluster.impl.operations
 

Subclasses of AbstractOperation 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
           
 

Uses of AbstractOperation in com.hazelcast.collection
 

Subclasses of AbstractOperation in com.hazelcast.collection
 class CollectionReplicationOperation
           
 

Uses of AbstractOperation in com.hazelcast.collection.list
 

Subclasses of AbstractOperation in com.hazelcast.collection.list
 class ListReplicationOperation
           
 

Uses of AbstractOperation in com.hazelcast.collection.set
 

Subclasses of AbstractOperation in com.hazelcast.collection.set
 class SetReplicationOperation
           
 

Uses of AbstractOperation in com.hazelcast.concurrent.atomiclong.operations
 

Subclasses of AbstractOperation in com.hazelcast.concurrent.atomiclong.operations
 class AtomicLongReplicationOperation
           
 

Uses of AbstractOperation in com.hazelcast.concurrent.atomicreference.operations
 

Subclasses of AbstractOperation in com.hazelcast.concurrent.atomicreference.operations
 class AtomicReferenceReplicationOperation
           
 

Uses of AbstractOperation in com.hazelcast.concurrent.countdownlatch.operations
 

Subclasses of AbstractOperation in com.hazelcast.concurrent.countdownlatch.operations
 class CountDownLatchBackupOperation
           
 class CountDownLatchReplicationOperation
           
 class CountDownOperation
           
 class GetCountOperation
           
 class SetCountOperation
           
 

Uses of AbstractOperation in com.hazelcast.concurrent.lock.operations
 

Subclasses of AbstractOperation 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
           
 

Uses of AbstractOperation in com.hazelcast.concurrent.semaphore.operations
 

Subclasses of AbstractOperation 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
           
 

Uses of AbstractOperation in com.hazelcast.executor.impl.operations
 

Subclasses of AbstractOperation in com.hazelcast.executor.impl.operations
 class ShutdownOperation
           
 

Uses of AbstractOperation in com.hazelcast.map.impl.operation
 

Subclasses of AbstractOperation in com.hazelcast.map.impl.operation
 class AbstractMapOperation
           
 class AddIndexOperation
           
 class AddInterceptorOperation
           
 class ClearBackupOperation
           
 class ClearExpiredOperation
          Clear expired records.
 class ClearOperation
           
 class ContainsValueOperation
           
 class EvictAllBackupOperation
          Operation which evicts all keys except locked ones.
 class EvictAllOperation
          Operation which evicts all keys except locked ones.
 class GetAllOperation
           
 class InvalidateNearCacheOperation
           
 class LoadAllOperation
          Triggers map store load of all given keys.
 class MapEntrySetOperation
           
 class MapFlushOperation
           
 class MapIsEmptyOperation
           
 class MapKeySetOperation
           
 class MapReplicationOperation
           
 class MapSizeOperation
           
 class MapValuesOperation
           
 class MultipleEntryBackupOperation
           
 class MultipleEntryOperation
           
 class NearCacheKeySetInvalidationOperation
          User: ahmetmircik Date: 10/31/13
 class PartitionCheckIfLoadedOperation
           
 class PartitionWideEntryBackupOperation
           
 class PartitionWideEntryOperation
          GOTCHA : This operation does NOT load missing keys from map-store for now.
 class PartitionWideEntryWithPredicateBackupOperation
           
 class PartitionWideEntryWithPredicateOperation
           
 class PostJoinMapOperation
           
 class PutAllBackupOperation
           
 class PutAllOperation
           
 class PutFromLoadAllBackupOperation
          Runs on backups.
 class PutFromLoadAllOperation
          Puts records to map which are loaded from map store by IMap.loadAll(boolean)
 class QueryOperation
           
 class QueryPartitionOperation
           
 class RemoveInterceptorOperation
           
 

Uses of AbstractOperation in com.hazelcast.mapreduce.impl.operation
 

Subclasses of AbstractOperation 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
 

Uses of AbstractOperation in com.hazelcast.multimap.impl.operations
 

Subclasses of AbstractOperation in com.hazelcast.multimap.impl.operations
 class MultiMapMigrationOperation
           
 

Uses of AbstractOperation in com.hazelcast.partition.impl
 

Subclasses of AbstractOperation in com.hazelcast.partition.impl
 class AssignPartitions
           
 class BaseMigrationOperation
           
 class HasOngoingMigration
           
 class MigrationOperation
           
 class MigrationRequestOperation
           
 class PartitionStateOperation
           
 class SafeStateCheckOperation
          Checks whether a node is safe or not.
 

Uses of AbstractOperation in com.hazelcast.queue.impl.operations
 

Subclasses of AbstractOperation in com.hazelcast.queue.impl.operations
 class QueueReplicationOperation
          Replication operation for the Queue.
 

Uses of AbstractOperation in com.hazelcast.replicatedmap.impl.operation
 

Subclasses of AbstractOperation in com.hazelcast.replicatedmap.impl.operation
 class ReplicatedMapClearOperation
          This operation will execute the remote clear on replicated map if ReplicatedMap.clear() is called.
 

Uses of AbstractOperation in com.hazelcast.spi.impl
 

Subclasses of AbstractOperation 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
           
 

Uses of AbstractOperation in com.hazelcast.topic.impl
 

Subclasses of AbstractOperation in com.hazelcast.topic.impl
 class PublishOperation
           
 



Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.