Infinispan Distribution 5.2.6.Final-redhat-2

Uses of Interface
org.infinispan.commands.ReplicableCommand

Packages that use ReplicableCommand
org.infinispan.commands Commands that operate on the cache, either locally or remotely. 
org.infinispan.commands.control   
org.infinispan.commands.module   
org.infinispan.commands.read   
org.infinispan.commands.remote Meta-commands that wrap other commands for remote execution. 
org.infinispan.commands.remote.recovery   
org.infinispan.commands.tx Commands that represent transactional lifecycle transitions. 
org.infinispan.commands.write Commands that alter the state of the cache. 
org.infinispan.marshall.exts Externalizers for various JDK types that are marshalled using the marshalling framework. 
org.infinispan.query   
org.infinispan.query.clustered   
org.infinispan.query.indexmanager   
org.infinispan.remoting Remote communication between cache instances. 
org.infinispan.remoting.rpc Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances. 
org.infinispan.remoting.transport Transports handle the low-level networking, used by the remoting components. 
org.infinispan.remoting.transport.jgroups A transport implementation based on JGroups
org.infinispan.statetransfer Transfer of state to new caches in a cluster. 
org.infinispan.topology   
org.infinispan.util General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and collections and containers designed to supplement the JDK-provided containers. 
org.infinispan.util.logging Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines. 
org.infinispan.xsite   
 

Uses of ReplicableCommand in org.infinispan.commands
 

Subinterfaces of ReplicableCommand in org.infinispan.commands
 interface CancellableCommand
          CancellableCommand is a command whose execution in remote VM can be canceled (if needed)
 interface DataCommand
          Commands of this type manipulate data in the cache.
 interface FlagAffectedCommand
          Commands affected by Flags should carry them over to the remote nodes.
 interface TopologyAffectedCommand
          Some of the commands sent over the wire can only be honored by the receiver if the topology of the cluster at delivery time is still 'compatible' with the topology in place at send time (eg.
 interface VisitableCommand
          A type of command that can accept Visitors, such as CommandInterceptors.
 

Classes in org.infinispan.commands that implement ReplicableCommand
 class AbstractFlagAffectedCommand
          Base class for those commands that can carry flags.
 class CancelCommand
          Command to cancel commands executing in remote VM
 class CreateCacheCommand
          Command to create/start a cache on a subset of Infinispan cluster nodes
 class RemoveCacheCommand
          Command to stop a cache and remove all its contents from both memory and any backing store.
 

Methods in org.infinispan.commands that return ReplicableCommand
 ReplicableCommand RemoteCommandsFactory.fromStream(byte id, Object[] parameters, byte type)
          Creates an un-initialized command.
 

Methods in org.infinispan.commands with parameters of type ReplicableCommand
 SingleRpcCommand CommandsFactory.buildSingleRpcCommand(ReplicableCommand call)
          Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
 SingleRpcCommand CommandsFactoryImpl.buildSingleRpcCommand(ReplicableCommand call)
           
 void CommandsFactory.initializeReplicableCommand(ReplicableCommand command, boolean isRemote)
          Initializes a ReplicableCommand read from a data stream with components specific to the target cache instance.
 void CommandsFactoryImpl.initializeReplicableCommand(ReplicableCommand c, boolean isRemote)
           
 

Method parameters in org.infinispan.commands with type arguments of type ReplicableCommand
 MultipleRpcCommand CommandsFactory.buildReplicateCommand(List<ReplicableCommand> toReplicate)
          Builds an RpcCommand "envelope" containing multiple ReplicableCommands
 MultipleRpcCommand CommandsFactoryImpl.buildReplicateCommand(List<ReplicableCommand> toReplicate)
           
 

Uses of ReplicableCommand in org.infinispan.commands.control
 

Classes in org.infinispan.commands.control that implement ReplicableCommand
 class LockControlCommand
          LockControlCommand is a command that enables distributed locking across infinispan nodes.
 

Uses of ReplicableCommand in org.infinispan.commands.module
 

Methods in org.infinispan.commands.module that return ReplicableCommand
 ReplicableCommand ModuleCommandFactory.fromStream(byte commandId, Object[] args)
          Construct and initialize a ReplicableCommand based on the command id and argument array passed in.
 

Methods in org.infinispan.commands.module that return types with arguments of type ReplicableCommand
 Map<Byte,Class<? extends ReplicableCommand>> ModuleCommandFactory.getModuleCommands()
          Provides a map of command IDs to command types of all the commands handled by the command factory instance.
 

Methods in org.infinispan.commands.module with parameters of type ReplicableCommand
 void ModuleCommandInitializer.initializeReplicableCommand(ReplicableCommand c, boolean isRemote)
          Initializes a command constructed using ModuleCommandFactory.fromStream(byte, Object[]) with necessary named-cache-specific components.
 

Uses of ReplicableCommand in org.infinispan.commands.read
 

Classes in org.infinispan.commands.read that implement ReplicableCommand
 class AbstractDataCommand
           
 class DistributedExecuteCommand<V>
          DistributedExecuteCommand is used to migrate Callable and execute it in remote JVM.
 class EntrySetCommand
          Command implementation for Map.entrySet() functionality.
 class GetCacheEntryCommand
          An internal cache get command that returns CacheEntry instead of just the value.
 class GetKeyValueCommand
          Implements functionality defined by Map.get(Object) and Map.containsKey(Object) operations
 class KeySetCommand
          Command implementation for Map.keySet() functionality.
 class MapCombineCommand<KIn,VIn,KOut,VOut>
          MapCombineCommand is a container to migrate Mapper and Reducer which is a combiner to a remote Infinispan node where it will get executed and return the result to an invoking/master node.
 class ReduceCommand<KOut,VOut>
          ReduceCommand is a container to migrate Reducer to a remote Infinispan node where it will get executed and return the result to an invoking/master node.
 class SizeCommand
          Command to calculate the size of the cache
 class ValuesCommand
          Command implementation for Map.values() functionality.
 

Uses of ReplicableCommand in org.infinispan.commands.remote
 

Subinterfaces of ReplicableCommand in org.infinispan.commands.remote
 interface CacheRpcCommand
          The RpcManager only replicates commands wrapped in a CacheRpcCommand.
 

Classes in org.infinispan.commands.remote that implement ReplicableCommand
 class BaseRpcCommand
           
 class BaseRpcInvokingCommand
          Base class for RPC commands.
 class ClusteredGetCommand
          Issues a remote get call.
 class MultipleRpcCommand
          Command that implements cluster replication logic.
 class SingleRpcCommand
          Similar to MultipleRpcCommand, but it only aggregates a single command for replication.
 

Methods in org.infinispan.commands.remote that return ReplicableCommand
 ReplicableCommand SingleRpcCommand.getCommand()
           
 ReplicableCommand[] MultipleRpcCommand.getCommands()
           
 

Methods in org.infinispan.commands.remote with parameters of type ReplicableCommand
protected  Object BaseRpcInvokingCommand.processVisitableCommand(ReplicableCommand cacheCommand)
           
 

Constructors in org.infinispan.commands.remote with parameters of type ReplicableCommand
SingleRpcCommand(String cacheName, ReplicableCommand command)
           
 

Constructor parameters in org.infinispan.commands.remote with type arguments of type ReplicableCommand
MultipleRpcCommand(List<ReplicableCommand> modifications, String cacheName)
           
 

Uses of ReplicableCommand in org.infinispan.commands.remote.recovery
 

Classes in org.infinispan.commands.remote.recovery that implement ReplicableCommand
 class CompleteTransactionCommand
          Command used by the recovery tooling for forcing transaction completion .
 class GetInDoubtTransactionsCommand
          Rpc to obtain all in-doubt prepared transactions stored on remote nodes.
 class GetInDoubtTxInfoCommand
          Command used by the recovery tooling for obtaining the list of in-doubt transactions from a node.
 class RecoveryCommand
          Base class for recovery-related rpc-commands.
 class TxCompletionNotificationCommand
          Command for removing recovery related information from the cluster.
 

Uses of ReplicableCommand in org.infinispan.commands.tx
 

Subinterfaces of ReplicableCommand in org.infinispan.commands.tx
 interface TransactionBoundaryCommand
          An transaction boundary command that allows the retrieval of an attached GlobalTransaction
 

Classes in org.infinispan.commands.tx that implement ReplicableCommand
 class AbstractTransactionBoundaryCommand
          An abstract transaction boundary command that holds a reference to a GlobalTransaction
 class CommitCommand
          Command corresponding to the 2nd phase of 2PC.
 class PrepareCommand
          Command corresponding to the 1st phase of 2PC.
 class RollbackCommand
          Command corresponding to a transaction rollback.
 class VersionedCommitCommand
          The same as a CommitCommand except that version information is also carried by this command, used by optimistically transactional caches making use of write skew checking when using IsolationLevel.REPEATABLE_READ.
 class VersionedPrepareCommand
          Same as PrepareCommand except that the transaction originator makes evident the versions of entries touched and stored in a transaction context so that accurate write skew checks may be performed by the lock owner(s).
 

Uses of ReplicableCommand in org.infinispan.commands.write
 

Subinterfaces of ReplicableCommand in org.infinispan.commands.write
 interface DataWriteCommand
          Mixes features from DataCommand and WriteCommand
 interface WriteCommand
          A command that modifies the cache in some way
 

Classes in org.infinispan.commands.write that implement ReplicableCommand
 class AbstractDataWriteCommand
          Stuff common to WriteCommands
 class ApplyDeltaCommand
           
 class ClearCommand
           
 class EvictCommand
           
 class InvalidateCommand
          Removes an entry from memory.
 class InvalidateL1Command
          Invalidates an entry in a L1 cache (used with DIST mode)
 class PutKeyValueCommand
          Implements functionality defined by BasicCache.put(Object, Object)
 class PutMapCommand
           
 class RemoveCommand
           
 class ReplaceCommand
           
 class VersionedPutKeyValueCommand
          A form of PutKeyValueCommand that also applies a version to the entry created.
 

Uses of ReplicableCommand in org.infinispan.marshall.exts
 

Methods in org.infinispan.marshall.exts that return ReplicableCommand
 ReplicableCommand ReplicableCommandExternalizer.readObject(ObjectInput input)
           
 

Methods in org.infinispan.marshall.exts that return types with arguments of type ReplicableCommand
 Set<Class<? extends ReplicableCommand>> ReplicableCommandExternalizer.getTypeClasses()
           
 

Methods in org.infinispan.marshall.exts with parameters of type ReplicableCommand
protected  void ReplicableCommandExternalizer.writeCommandHeader(ObjectOutput output, ReplicableCommand command)
           
protected  void ReplicableCommandExternalizer.writeCommandParameters(ObjectOutput output, ReplicableCommand command)
           
 void ReplicableCommandExternalizer.writeObject(ObjectOutput output, ReplicableCommand command)
           
 

Uses of ReplicableCommand in org.infinispan.query
 

Methods in org.infinispan.query that return ReplicableCommand
 ReplicableCommand CommandFactory.fromStream(byte commandId, Object[] args)
           
 

Methods in org.infinispan.query that return types with arguments of type ReplicableCommand
 Map<Byte,Class<? extends ReplicableCommand>> CommandFactory.getModuleCommands()
           
 

Methods in org.infinispan.query with parameters of type ReplicableCommand
 void CommandInitializer.initializeReplicableCommand(ReplicableCommand c, boolean isRemote)
           
 

Uses of ReplicableCommand in org.infinispan.query.clustered
 

Classes in org.infinispan.query.clustered that implement ReplicableCommand
 class ClusteredQueryCommand
          Encapsulates all rpc calls for distributed queries actions
 

Uses of ReplicableCommand in org.infinispan.query.indexmanager
 

Classes in org.infinispan.query.indexmanager that implement ReplicableCommand
 class IndexUpdateCommand
          Custom RPC command containing an index update request for the Master IndexManager of a specific cache & index.
 

Uses of ReplicableCommand in org.infinispan.remoting
 

Methods in org.infinispan.remoting that return types with arguments of type ReplicableCommand
protected  List<ReplicableCommand> ReplicationQueueImpl.drainReplQueue()
           
 

Methods in org.infinispan.remoting with parameters of type ReplicableCommand
 void ReplicationQueueImpl.add(ReplicableCommand job)
           
 void ReplicationQueue.add(ReplicableCommand job)
          Adds a new command to the replication queue.
 

Uses of ReplicableCommand in org.infinispan.remoting.rpc
 

Methods in org.infinispan.remoting.rpc with parameters of type ReplicableCommand
 void RpcManager.broadcastRpcCommand(ReplicableCommand rpc, boolean sync)
          Broadcasts an RPC command to the entire cluster.
 void RpcManagerImpl.broadcastRpcCommand(ReplicableCommand rpc, boolean sync)
           
 void RpcManager.broadcastRpcCommand(ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
          Broadcasts an RPC command to the entire cluster.
 void RpcManagerImpl.broadcastRpcCommand(ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
           
 void RpcManager.broadcastRpcCommandInFuture(ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future)
          The same as RpcManager.broadcastRpcCommand(org.infinispan.commands.ReplicableCommand, boolean, boolean) except that the task is passed to the transport executor and a Future is returned.
 void RpcManagerImpl.broadcastRpcCommandInFuture(ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l)
           
 void RpcManager.broadcastRpcCommandInFuture(ReplicableCommand rpc, NotifyingNotifiableFuture<Object> future)
          The same as RpcManager.broadcastRpcCommand(org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
 void RpcManagerImpl.broadcastRpcCommandInFuture(ReplicableCommand rpc, NotifyingNotifiableFuture<Object> l)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync)
          Broadcasts an RPC command to a specified set of recipients
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
          Broadcasts an RPC command to a specified set of recipients
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue)
           
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, boolean sync, boolean usePriorityQueue, long timeout)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue)
           
 Map<Address,Response> RpcManager.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
          Invokes an RPC call on other caches in the cluster.
 Map<Address,Response> RpcManagerImpl.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future)
          The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future, long timeout)
          The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture) except that you can specify a timeout.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l, long timeout)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> future, long timeout, boolean ignoreLeavers)
          The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture, long) except that you can specify a response mode.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, boolean usePriorityQueue, NotifyingNotifiableFuture<Object> l, long timeout, boolean ignoreLeavers)
           
 void RpcManager.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, NotifyingNotifiableFuture<Object> future)
          The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
 void RpcManagerImpl.invokeRemotelyInFuture(Collection<Address> recipients, ReplicableCommand rpc, NotifyingNotifiableFuture<Object> l)
           
 

Uses of ReplicableCommand in org.infinispan.remoting.transport
 

Methods in org.infinispan.remoting.transport with parameters of type ReplicableCommand
 BackupResponse Transport.backupRemotely(Collection<XSiteBackup> backups, ReplicableCommand rpcCommand)
           
 Map<Address,Response> Transport.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
          Invokes an RPC call on other caches in the cluster.
 

Uses of ReplicableCommand in org.infinispan.remoting.transport.jgroups
 

Methods in org.infinispan.remoting.transport.jgroups with parameters of type ReplicableCommand
 BackupResponse JGroupsTransport.backupRemotely(Collection<XSiteBackup> backups, ReplicableCommand rpcCommand)
           
 org.jgroups.util.RspList<Object> CommandAwareRpcDispatcher.broadcastRemoteCommands(ReplicableCommand command, org.jgroups.blocks.ResponseMode mode, long timeout, boolean anycasting, boolean oob, org.jgroups.blocks.RspFilter filter, boolean asyncMarshalling, boolean ignoreLeavers)
           
 Response CommandAwareRpcDispatcher.invokeRemoteCommand(org.jgroups.Address recipient, ReplicableCommand command, org.jgroups.blocks.ResponseMode mode, long timeout, boolean oob, boolean asyncMarshalling)
           
 org.jgroups.util.RspList<Object> CommandAwareRpcDispatcher.invokeRemoteCommands(List<org.jgroups.Address> recipients, ReplicableCommand command, org.jgroups.blocks.ResponseMode mode, long timeout, boolean anycasting, boolean oob, org.jgroups.blocks.RspFilter filter, boolean asyncMarshalling, boolean ignoreLeavers)
           
 Map<Address,Response> JGroupsTransport.invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter)
           
 

Uses of ReplicableCommand in org.infinispan.statetransfer
 

Classes in org.infinispan.statetransfer that implement ReplicableCommand
 class StateRequestCommand
          This command is used by a StateConsumer to request transactions and cache entries from a StateProvider.
 class StateResponseCommand
          This command is used by a StateProvider to push cache entries to a StateConsumer.
 

Uses of ReplicableCommand in org.infinispan.topology
 

Classes in org.infinispan.topology that implement ReplicableCommand
 class CacheTopologyControlCommand
          A control command for all cache membership/rebalance operations.
 

Uses of ReplicableCommand in org.infinispan.util
 

Methods in org.infinispan.util that return types with arguments of type ReplicableCommand
 Collection<Class<? extends ReplicableCommand>> ModuleProperties.moduleCommands()
           
 Collection<Class<? extends ReplicableCommand>> ModuleProperties.moduleOnlyReplicableCommands()
           
 

Uses of ReplicableCommand in org.infinispan.util.logging
 

Methods in org.infinispan.util.logging with parameters of type ReplicableCommand
 void Log.exceptionHandlingCommand(ReplicableCommand cmd, Throwable t)
           
 

Uses of ReplicableCommand in org.infinispan.xsite
 

Classes in org.infinispan.xsite that implement ReplicableCommand
 class XSiteAdminCommand
          Command used for handling XSiteReplication administrative operations.
 


Infinispan Distribution 5.2.6.Final-redhat-2

Copyright © 2013 JBoss, a division of Red Hat. All Rights Reserved.