Uses of Interface
com.hazelcast.spi.impl.RemotePropagatable

Packages that use RemotePropagatable
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.collection.txn This package contains the Transaction behavior for the Collections.
 
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.management.operation Contains operations that are called from Management Center. 
com.hazelcast.map.impl.operation Package for map operations. 
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.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.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.transaction.impl Provides implementation for Hazelcast transaction support. 
 

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

Classes in com.hazelcast.cache.impl.operation that implement RemotePropagatable
 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 RemotePropagatable in com.hazelcast.client.impl.operations
 

Classes in com.hazelcast.client.impl.operations that implement RemotePropagatable
 class ClientDisconnectionOperation
           
 class ClientReAuthOperation
           
 class PostJoinClientOperation
           
 

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

Classes in com.hazelcast.cluster.impl.operations that implement RemotePropagatable
 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 RemotePropagatable in com.hazelcast.collection
 

Classes in com.hazelcast.collection that implement RemotePropagatable
 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
           
 

Uses of RemotePropagatable in com.hazelcast.collection.list
 

Classes in com.hazelcast.collection.list that implement RemotePropagatable
 class ListAddAllOperation
           
 class ListAddOperation
           
 class ListGetOperation
           
 class ListIndexOfOperation
           
 class ListRemoveOperation
           
 class ListReplicationOperation
           
 class ListSetBackupOperation
           
 class ListSetOperation
           
 class ListSubOperation
           
 

Uses of RemotePropagatable in com.hazelcast.collection.set
 

Classes in com.hazelcast.collection.set that implement RemotePropagatable
 class SetReplicationOperation
           
 

Uses of RemotePropagatable in com.hazelcast.collection.txn
 

Classes in com.hazelcast.collection.txn that implement RemotePropagatable
 class CollectionPrepareBackupOperation
           
 class CollectionPrepareOperation
           
 class CollectionReserveAddOperation
           
 class CollectionReserveRemoveOperation
           
 class CollectionRollbackBackupOperation
           
 class CollectionRollbackOperation
           
 class CollectionTxnAddBackupOperation
           
 class CollectionTxnAddOperation
           
 class CollectionTxnRemoveBackupOperation
           
 class CollectionTxnRemoveOperation
           
 

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

Classes in com.hazelcast.concurrent.atomiclong.operations that implement RemotePropagatable
 class AddAndGetOperation
           
 class AddBackupOperation
           
 class AtomicLongBackupAwareOperation
           
 class AtomicLongBaseOperation
           
 class AtomicLongReplicationOperation
           
 class GetAndAddOperation
           
 

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

Classes in com.hazelcast.concurrent.atomicreference.operations that implement RemotePropagatable
 class AbstractAlterOperation
           
 class AlterAndGetOperation
           
 class AlterOperation
           
 class ApplyOperation
           
 class AtomicReferenceBackupAwareOperation
           
 class AtomicReferenceBaseOperation
           
 class AtomicReferenceReplicationOperation
           
 class CompareAndSetOperation
           
 class GetAndAlterOperation
           
 class GetAndSetOperation
           
 class IsNullOperation
           
 class SetAndGetOperation
           
 class SetBackupOperation
           
 

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

Classes in com.hazelcast.concurrent.countdownlatch.operations that implement RemotePropagatable
 class AwaitOperation
           
 class CountDownLatchBackupOperation
           
 class CountDownLatchReplicationOperation
           
 class CountDownOperation
           
 class GetCountOperation
           
 class SetCountOperation
           
 

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

Classes in com.hazelcast.concurrent.lock.operations that implement RemotePropagatable
 class AwaitBackupOperation
           
 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 RemotePropagatable in com.hazelcast.concurrent.semaphore.operations
 

Classes in com.hazelcast.concurrent.semaphore.operations that implement RemotePropagatable
 class AcquireBackupOperation
           
 class AcquireOperation
           
 class AvailableOperation
           
 class DeadMemberBackupOperation
           
 class InitBackupOperation
           
 class InitOperation
           
 class ReduceBackupOperation
           
 class ReduceOperation
           
 class ReleaseBackupOperation
           
 class ReleaseOperation
           
 class SemaphoreBackupAwareOperation
           
 class SemaphoreBackupOperation
           
 class SemaphoreDeadMemberOperation
           
 class SemaphoreOperation
           
 class SemaphoreReplicationOperation
           
 

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

Classes in com.hazelcast.executor.impl.operations that implement RemotePropagatable
 class CallableTaskOperation
           
 class CancellationOperation
           
 class MemberCallableTaskOperation
           
 class ShutdownOperation
           
 

Uses of RemotePropagatable in com.hazelcast.management.operation
 

Classes in com.hazelcast.management.operation that implement RemotePropagatable
 class GetMapConfigOperation
          Operation to fetch Map configuration.
 class ScriptExecutorOperation
          Operation to execute script on the node.
 class ThreadDumpOperation
          Operation for generating thread dumps.
 class UpdateManagementCenterUrlOperation
          Operation to update Management Center URL configured on the node.
 class UpdateMapConfigOperation
          Operation to update map configuration from Management Center.
 

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

Classes in com.hazelcast.map.impl.operation that implement RemotePropagatable
 class AbstractMapOperation
           
 class AddIndexOperation
           
 class AddInterceptorOperation
           
 class BasePutOperation
           
 class BaseRemoveOperation
           
 class ClearExpiredOperation
          Clear expired records.
 class ContainsKeyOperation
           
 class ContainsValueOperation
           
 class DeleteOperation
           
 class EntryBackupOperation
           
 class EntryOperation
          GOTCHA : This operation LOADS missing keys from map-store, in contrast with PartitionWideEntryOperation.
 class EvictAllBackupOperation
          Operation which evicts all keys except locked ones.
 class EvictAllOperation
          Operation which evicts all keys except locked ones.
 class EvictOperation
           
 class GetEntryViewOperation
           
 class GetOperation
           
 class InvalidateNearCacheOperation
           
 class KeyBasedMapOperation
           
 class LoadAllOperation
          Triggers map store load of all given keys.
 class LockAwareOperation
           
 class MapEntrySetOperation
           
 class MapFlushOperation
           
 class MapIsEmptyOperation
           
 class MapKeySetOperation
           
 class MapReplicationOperation
           
 class MapSizeOperation
           
 class MapValuesOperation
           
 class MergeOperation
           
 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 PutIfAbsentOperation
           
 class PutTransientOperation
           
 class QueryOperation
           
 class QueryPartitionOperation
           
 class RemoveIfSameOperation
           
 class RemoveInterceptorOperation
           
 class ReplaceIfSameOperation
           
 class ReplaceOperation
           
 class SetOperation
           
 class TryPutOperation
           
 class TryRemoveOperation
           
 class WanOriginatedDeleteOperation
           
 

Uses of RemotePropagatable in com.hazelcast.map.impl.tx
 

Classes in com.hazelcast.map.impl.tx that implement RemotePropagatable
 class TxnDeleteOperation
          Transactional delete operation
 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.
 

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

Classes in com.hazelcast.mapreduce.impl.operation that implement RemotePropagatable
 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 RemotePropagatable in com.hazelcast.multimap.impl.operations
 

Classes in com.hazelcast.multimap.impl.operations that implement RemotePropagatable
 class ContainsEntryOperation
           
 class CountOperation
           
 class EntrySetOperation
           
 class GetAllOperation
           
 class KeySetOperation
           
 class MultiMapBackupAwareOperation
           
 class MultiMapKeyBasedOperation
           
 class MultiMapMigrationOperation
           
 class MultiMapOperation
           
 class PutBackupOperation
           
 class PutOperation
           
 class RemoveAllBackupOperation
           
 class RemoveAllOperation
           
 class ValuesOperation
           
 

Uses of RemotePropagatable in com.hazelcast.multimap.impl.txn
 

Classes in com.hazelcast.multimap.impl.txn that implement RemotePropagatable
 class TxnCommitBackupOperation
           
 class TxnCommitOperation
           
 class TxnGenerateRecordIdOperation
           
 class TxnLockAndGetOperation
           
 class TxnPutBackupOperation
           
 class TxnPutOperation
           
 class TxnRemoveAllBackupOperation
           
 class TxnRemoveAllOperation
           
 class TxnRemoveBackupOperation
           
 class TxnRemoveOperation
           
 

Uses of RemotePropagatable in com.hazelcast.partition.impl
 

Classes in com.hazelcast.partition.impl that implement RemotePropagatable
 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.
 

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

Classes in com.hazelcast.queue.impl.operations that implement RemotePropagatable
 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 ClearBackupOperation
          Store items' id as set when ClearOperation run.
 class ClearOperation
          Clears items stored by 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 ContainsOperation
          Checks whether contain or not item in the Queue.
 class DrainBackupOperation
          This class stores items' id when DrainOperation run.
 class DrainOperation
          This class drain items according to drain condition.
 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
 class RemoveBackupOperation
          Remove backup of the Queue item.
 class RemoveOperation
          Remove operation for the Queue.
 class SizeOperation
          Notify size of the queue.
 

Uses of RemotePropagatable in com.hazelcast.queue.impl.tx
 

Classes in com.hazelcast.queue.impl.tx that implement RemotePropagatable
 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 TxnPrepareBackupOperation
          Provides backup operation during transactional prepare operation.
 class TxnPrepareOperation
          Prepare 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.
 class TxnRollbackBackupOperation
          Provides backup operation during transactional rollback operation.
 class TxnRollbackOperation
          Rollback operation for the transactional queue.
 

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

Classes in com.hazelcast.replicatedmap.impl.operation that implement RemotePropagatable
 class AbstractReplicatedMapOperation
          Base class for replicated map remote operations
 class ReplicatedMapClearOperation
          This operation will execute the remote clear on replicated map if ReplicatedMap.clear() is called.
 class ReplicatedMapInitChunkOperation
          Class for requesting an initial chunk of data from another node to pre-provision newly joining members
 class ReplicatedMapPostJoinOperation
          The replicated map post join operation to execute on remote nodes
 

Uses of RemotePropagatable in com.hazelcast.spi
 

Classes in com.hazelcast.spi that implement RemotePropagatable
 class AbstractOperation
          Abstract Operation implementation with some basic methods implemented.
 class Operation
          An operation could be compared the a Runnable.
 

Uses of RemotePropagatable in com.hazelcast.spi.impl
 

Classes in com.hazelcast.spi.impl with type parameters of type RemotePropagatable
 interface RemotePropagatable<T extends RemotePropagatable>
           
 

Classes in com.hazelcast.spi.impl that implement RemotePropagatable
 class AbstractNamedOperation
           
static class EventServiceImpl.DeregistrationOperation
           
static class EventServiceImpl.PostJoinRegistrationOperation
           
static class EventServiceImpl.RegistrationOperation
           
static class EventServiceImpl.SendEventOperation
           
 class IsStillExecutingOperation
          An operation that checks if another operation is still running.
 class PartitionIteratingOperation
           
static class ProxyServiceImpl.DistributedObjectDestroyOperation
           
static class ProxyServiceImpl.PostJoinProxyOperation
           
 class TraceableIsStillExecutingOperation
           
 

Methods in com.hazelcast.spi.impl with parameters of type RemotePropagatable
static ResponseHandler ResponseHandlerFactory.createRemoteResponseHandler(NodeEngine nodeEngine, RemotePropagatable remotePropagatable)
           
static void ResponseHandlerFactory.setRemoteResponseHandler(NodeEngine nodeEngine, RemotePropagatable remotePropagatable)
           
 

Uses of RemotePropagatable in com.hazelcast.topic.impl
 

Classes in com.hazelcast.topic.impl that implement RemotePropagatable
 class PublishOperation
           
 

Uses of RemotePropagatable in com.hazelcast.transaction.impl
 

Classes in com.hazelcast.transaction.impl that implement RemotePropagatable
 class BeginTxBackupOperation
           
 class BroadcastTxRollbackOperation
           
 class PurgeTxBackupOperation
           
 class RecoverTxnOperation
           
 class ReplicateTxOperation
           
 class RollbackTxBackupOperation
           
 



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