Uses of Interface
org.infinispan.commands.ReplicableCommand
-
Packages that use ReplicableCommand Package Description org.infinispan.commands Commands that operate on the cache, either locally or remotely.org.infinispan.commands.remote org.infinispan.expiration.impl org.infinispan.interceptors.distribution Interceptors dealing with command replication in distributed/replicated mode.org.infinispan.manager.impl org.infinispan.marshall.exts Externalizers for various JDK types that are marshalled using the marshalling framework.org.infinispan.query.affinity This package contains the implementation of the AffinityIndexManager, that maintains an index divided into shards with storage using the Infinispan Lucene directory.org.infinispan.query.clustered org.infinispan.query.impl Query module internals.org.infinispan.query.indexmanager org.infinispan.remoting.inboundhandler Handling of inbound commands on remote nodes.org.infinispan.remoting.inboundhandler.action 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.server.hotrod.command.tx org.infinispan.statetransfer Transfer of state to new caches in a cluster.org.infinispan.stats.wrappers org.infinispan.stream.impl 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.concurrent.locks Lock and synchronization related classes, tools and utilities.org.infinispan.util.logging Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.org.infinispan.xsite org.infinispan.xsite.statetransfer -
-
Uses of ReplicableCommand in org.infinispan.commands
Subinterfaces of ReplicableCommand in org.infinispan.commands Modifier and Type Interface Description 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
Flags modify behavior of command such as whether or not to invoke certain commands remotely, check cache store etc.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 acceptVisitor
s, such asDDAsyncInterceptor
.Classes in org.infinispan.commands that implement ReplicableCommand Modifier and Type Class Description class
AbstractFlagAffectedCommand
Base class for those commands that can carry flags.class
AbstractTopologyAffectedCommand
Base class for commands that carry topology id.class
CancelCommand
Command to cancel commands executing in remote VMclass
CreateCacheCommand
Command to create/start a cache on a subset of Infinispan cluster nodesclass
RemoveCacheCommand
Deprecated.UseCacheContainerAdmin.removeCache(String)
insteadMethods in org.infinispan.commands that return ReplicableCommand Modifier and Type Method Description ReplicableCommand
RemoteCommandsFactory. fromStream(byte id, byte type)
Creates an un-initialized command.Methods in org.infinispan.commands with parameters of type ReplicableCommand Modifier and Type Method Description org.infinispan.commands.remote.SingleRpcCommand
CommandsFactory. buildSingleRpcCommand(ReplicableCommand call)
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommandorg.infinispan.commands.remote.SingleRpcCommand
CommandsFactoryImpl. buildSingleRpcCommand(ReplicableCommand call)
static int
SegmentSpecificCommand. extractSegment(ReplicableCommand command, Object key, KeyPartitioner keyPartitioner)
Utility to extract the segment from a given command that may be aSegmentSpecificCommand
.void
CommandsFactory. initializeReplicableCommand(ReplicableCommand command, boolean isRemote)
Initializes aReplicableCommand
read from a data stream with components specific to the target cache instance.void
CommandsFactoryImpl. initializeReplicableCommand(ReplicableCommand c, boolean isRemote)
-
Uses of ReplicableCommand in org.infinispan.commands.remote
Subinterfaces of ReplicableCommand in org.infinispan.commands.remote with annotations of type with type parameters of type that implement declared as with annotations of type with type parameters of type with annotations of type with annotations of type with type parameters of type that return that return types with arguments of type with parameters of type with type arguments of type that throw with annotations of type with annotations of type with parameters of type with type arguments of type that throw Modifier and Type Interface Description interface
org.infinispan.commands.remote.CacheRpcCommand
TheRpcManager
only replicates commands wrapped in aCacheRpcCommand
.Classes in org.infinispan.commands.remote with annotations of type with type parameters of type that implement declared as with annotations of type with type parameters of type with annotations of type with annotations of type with type parameters of type that return that return types with arguments of type with parameters of type with type arguments of type that throw with annotations of type with annotations of type with parameters of type with type arguments of type that throw ReplicableCommand Modifier and Type Class Description class
org.infinispan.commands.remote.BaseRpcCommand
-
Uses of ReplicableCommand in org.infinispan.expiration.impl
Classes in org.infinispan.expiration.impl that implement ReplicableCommand Modifier and Type Class Description class
TouchCommand
This command can be invoked to update a cache entry's recent access. -
Uses of ReplicableCommand in org.infinispan.interceptors.distribution
Methods in org.infinispan.interceptors.distribution with parameters of type ReplicableCommand Modifier and Type Method Description protected DistributionInfo
BaseDistributionInterceptor. retrieveDistributionInfo(LocalizedCacheTopology topology, ReplicableCommand command, Object key)
-
Uses of ReplicableCommand in org.infinispan.manager.impl
Classes in org.infinispan.manager.impl that implement ReplicableCommand Modifier and Type Class Description class
ReplicableCommandManagerFunction
Replicable Command that runs the given Function passing theEmbeddedCacheManager
as an argumentclass
ReplicableCommandRunnable
Replicable Command that runs the given Runnable -
Uses of ReplicableCommand in org.infinispan.marshall.exts
Methods in org.infinispan.marshall.exts that return ReplicableCommand Modifier and Type Method Description ReplicableCommand
ReplicableCommandExternalizer. readObject(ObjectInput input)
Methods in org.infinispan.marshall.exts that return types with arguments of type ReplicableCommand Modifier and Type Method Description Set<Class<? extends ReplicableCommand>>
ReplicableCommandExternalizer. getTypeClasses()
Methods in org.infinispan.marshall.exts with parameters of type ReplicableCommand Modifier and Type Method Description 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.affinity
Classes in org.infinispan.query.affinity that implement ReplicableCommand Modifier and Type Class Description class
AffinityUpdateCommand
Handle index updates forwarded by theAffinityIndexManager
, in exceptional cases where an index work ceases to be local to a node due to transient ownership changes. -
Uses of ReplicableCommand in org.infinispan.query.clustered
Classes in org.infinispan.query.clustered that implement ReplicableCommand Modifier and Type Class Description class
ClusteredQueryCommand
Encapsulates all rpc calls for distributed queries actions. -
Uses of ReplicableCommand in org.infinispan.query.impl
Subinterfaces of ReplicableCommand in org.infinispan.query.impl Modifier and Type Interface Description interface
CustomQueryCommand
Custom commands from the Query module should implement this interface to fetch needed components. -
Uses of ReplicableCommand in org.infinispan.query.indexmanager
Classes in org.infinispan.query.indexmanager that implement ReplicableCommand Modifier and Type Class Description class
AbstractUpdateCommand
Base class for index commands.class
IndexUpdateCommand
Custom RPC command containing an index update request for the Master IndexManager of a specific cache and index.class
IndexUpdateStreamCommand
Execute a stream operation -
Uses of ReplicableCommand in org.infinispan.remoting.inboundhandler
Methods in org.infinispan.remoting.inboundhandler with parameters of type ReplicableCommand Modifier and Type Method Description void
GlobalInboundInvocationHandler. handleFromCluster(Address origin, ReplicableCommand command, Reply reply, DeliverOrder order)
void
InboundInvocationHandler. handleFromCluster(Address origin, ReplicableCommand command, Reply reply, DeliverOrder order)
Handles theReplicableCommand
from other node belonging to local site. -
Uses of ReplicableCommand in org.infinispan.remoting.inboundhandler.action
Methods in org.infinispan.remoting.inboundhandler.action with type parameters of type ReplicableCommand Modifier and Type Method Description <T extends ReplicableCommand>
TActionState. getCommand()
Constructors in org.infinispan.remoting.inboundhandler.action with parameters of type ReplicableCommand Constructor Description ActionState(ReplicableCommand command, int commandTopologyId, long timeout)
-
Uses of ReplicableCommand in org.infinispan.remoting.rpc
Methods in org.infinispan.remoting.rpc with parameters of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
RpcManager. invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
Invoke a command on a collection of node and pass the responses to aResponseCollector
.<T> CompletionStage<T>
RpcManager. invokeCommand(Address target, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
Invoke a command on a single node and pass the response to aResponseCollector
.<T> CompletionStage<T>
RpcManagerImpl. invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
<T> CompletionStage<T>
RpcManagerImpl. invokeCommand(Address target, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
<T> CompletionStage<T>
RpcManager. invokeCommandOnAll(ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
Invoke a command on all the nodes in the cluster and pass the responses to aResponseCollector
.<T> CompletionStage<T>
RpcManagerImpl. invokeCommandOnAll(ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
<T> CompletionStage<T>
RpcManager. invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
Invoke a command on a collection of nodes and pass the responses to aResponseCollector
.<T> CompletionStage<T>
RpcManagerImpl. invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
Map<Address,Response>
RpcManager. invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options)
Deprecated.Since 9.2, please useRpcManager.invokeCommand(Collection, ReplicableCommand, ResponseCollector, RpcOptions)
instead.Map<Address,Response>
RpcManagerImpl. invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options)
CompletableFuture<Map<Address,Response>>
RpcManager. invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options)
Invokes a command on remote nodes.CompletableFuture<Map<Address,Response>>
RpcManagerImpl. invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options)
void
RpcManager. sendTo(Address destination, ReplicableCommand command, DeliverOrder deliverOrder)
Asynchronously sends theReplicableCommand
to the destination using the specifiedDeliverOrder
.void
RpcManagerImpl. sendTo(Address destination, ReplicableCommand command, DeliverOrder deliverOrder)
void
RpcManager. sendToAll(ReplicableCommand command, DeliverOrder deliverOrder)
Asynchronously sends theReplicableCommand
to the entire cluster.void
RpcManagerImpl. sendToAll(ReplicableCommand command, DeliverOrder deliverOrder)
void
RpcManager. sendToMany(Collection<Address> destinations, ReplicableCommand command, DeliverOrder deliverOrder)
Asynchronously sends theReplicableCommand
to the set of destination using the specifiedDeliverOrder
.void
RpcManagerImpl. sendToMany(Collection<Address> destinations, ReplicableCommand command, DeliverOrder deliverOrder)
Method parameters in org.infinispan.remoting.rpc with type arguments of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
RpcManager. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)
Invoke different commands on a collection of nodes and pass the responses to aResponseCollector
.<T> CompletionStage<T>
RpcManagerImpl. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)
Map<Address,Response>
RpcManager. invokeRemotely(Map<Address,ReplicableCommand> rpcs, RpcOptions options)
Deprecated.Since 9.2, please useRpcManager.invokeCommands(Collection, Function, ResponseCollector, RpcOptions)
instead.Map<Address,Response>
RpcManagerImpl. invokeRemotely(Map<Address,ReplicableCommand> rpcs, RpcOptions options)
-
Uses of ReplicableCommand in org.infinispan.remoting.transport
Methods in org.infinispan.remoting.transport with parameters of type ReplicableCommand Modifier and Type Method Description protected BackupResponse
AbstractDelegatingTransport. afterBackupRemotely(ReplicableCommand command, BackupResponse response)
method invoked after a successful backup remote invocation.protected Map<Address,Response>
AbstractDelegatingTransport. afterInvokeRemotely(ReplicableCommand command, Map<Address,Response> responseMap)
method invoked after a successful remote invocation.protected void
AbstractDelegatingTransport. beforeInvokeRemotely(ReplicableCommand command)
method invoked before a remote invocation.<T> CompletionStage<T>
AbstractDelegatingTransport. invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
<T> CompletionStage<T>
AbstractDelegatingTransport. invokeCommand(Address target, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
default <T> CompletionStage<T>
Transport. invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
Invoke a command on a collection of node and pass the responses to aResponseCollector
.default <T> CompletionStage<T>
Transport. invokeCommand(Address target, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
Invoke a command on a single node and pass the response to aResponseCollector
.<T> CompletionStage<T>
AbstractDelegatingTransport. invokeCommandOnAll(ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
default <T> CompletionStage<T>
Transport. invokeCommandOnAll(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
Invoke a command on all the nodes in the cluster and pass the responses to aResponseCollector
.default <T> CompletionStage<T>
Transport. invokeCommandOnAll(ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
Invoke a command on all the nodes in the cluster and pass the responses to aResponseCollector
.<T> CompletionStage<T>
AbstractDelegatingTransport. invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
default <T> CompletionStage<T>
Transport. invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
Invoke a command on a collection of nodes and pass the responses to aResponseCollector
.Map<Address,Response>
AbstractDelegatingTransport. invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
default Map<Address,Response>
Transport. invokeRemotely(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
Deprecated.Since 9.2, please useTransport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)
instead.CompletableFuture<Map<Address,Response>>
AbstractDelegatingTransport. invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
CompletableFuture<Map<Address,Response>>
Transport. invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpcCommand, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
void
AbstractDelegatingTransport. sendTo(Address destination, ReplicableCommand rpcCommand, DeliverOrder deliverOrder)
void
Transport. sendTo(Address destination, ReplicableCommand rpcCommand, DeliverOrder deliverOrder)
Asynchronously sends theReplicableCommand
to the destination using the specifiedDeliverOrder
.void
AbstractDelegatingTransport. sendToAll(ReplicableCommand rpcCommand, DeliverOrder deliverOrder)
default void
Transport. sendToAll(ReplicableCommand rpcCommand, DeliverOrder deliverOrder)
Asynchronously sends theReplicableCommand
to the entire cluster.void
AbstractDelegatingTransport. sendToMany(Collection<Address> destinations, ReplicableCommand rpcCommand, DeliverOrder deliverOrder)
void
Transport. sendToMany(Collection<Address> destinations, ReplicableCommand rpcCommand, DeliverOrder deliverOrder)
Asynchronously sends theReplicableCommand
to the set of destination using the specifiedDeliverOrder
.Method parameters in org.infinispan.remoting.transport with type arguments of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
AbstractDelegatingTransport. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)
default <T> CompletionStage<T>
Transport. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> responseCollector, long timeout, DeliverOrder deliverOrder)
Deprecated.Introduced in 9.1, but replaced in 9.2 withTransport.invokeCommands(Collection, Function, ResponseCollector, DeliverOrder, long, TimeUnit)
.default <T> CompletionStage<T>
Transport. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)
Invoke different commands on a collection of nodes and pass the responses to aResponseCollector
.Map<Address,Response>
AbstractDelegatingTransport. invokeRemotely(Map<Address,ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast)
Map<Address,Response>
AbstractDelegatingTransport. invokeRemotely(Map<Address,ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
default Map<Address,Response>
Transport. invokeRemotely(Map<Address,ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, boolean usePriorityQueue, ResponseFilter responseFilter, boolean totalOrder, boolean anycast)
Deprecated.default Map<Address,Response>
Transport. invokeRemotely(Map<Address,ReplicableCommand> rpcCommands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
Deprecated.Since 9.2, please useTransport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)
instead. -
Uses of ReplicableCommand in org.infinispan.remoting.transport.jgroups
Methods in org.infinispan.remoting.transport.jgroups with parameters of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
JGroupsTransport. invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
<T> CompletionStage<T>
JGroupsTransport. invokeCommand(Address target, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
<T> CompletionStage<T>
JGroupsTransport. invokeCommandOnAll(Collection<Address> requiredTargets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
<T> CompletionStage<T>
JGroupsTransport. invokeCommandOnAll(ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
<T> CompletionStage<T>
JGroupsTransport. invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit unit)
CompletableFuture<Map<Address,Response>>
JGroupsTransport. invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand command, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
void
JGroupsTransport. sendTo(Address destination, ReplicableCommand command, DeliverOrder deliverOrder)
void
JGroupsTransport. sendToAll(ReplicableCommand command, DeliverOrder deliverOrder)
void
JGroupsTransport. sendToMany(Collection<Address> targets, ReplicableCommand command, DeliverOrder deliverOrder)
Method parameters in org.infinispan.remoting.transport.jgroups with type arguments of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
JGroupsTransport. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> collector, DeliverOrder deliverOrder, long timeout, TimeUnit timeUnit)
Map<Address,Response>
JGroupsTransport. invokeRemotely(Map<Address,ReplicableCommand> commands, ResponseMode mode, long timeout, ResponseFilter responseFilter, DeliverOrder deliverOrder, boolean anycast)
Deprecated. -
Uses of ReplicableCommand in org.infinispan.server.hotrod.command.tx
Classes in org.infinispan.server.hotrod.command.tx that implement ReplicableCommand Modifier and Type Class Description class
ForwardCommitCommand
ACacheRpcCommand
implementation to forward the commit request from a client to the member that run the transaction.class
ForwardRollbackCommand
ACacheRpcCommand
implementation to forward the rollback request from a client to the member that run the transaction. -
Uses of ReplicableCommand in org.infinispan.statetransfer
Classes in org.infinispan.statetransfer that implement ReplicableCommand Modifier and Type Class Description 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.stats.wrappers
Methods in org.infinispan.stats.wrappers with parameters of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
ExtendedStatisticRpcManager. invokeCommand(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
<T> CompletionStage<T>
ExtendedStatisticRpcManager. invokeCommand(Address target, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
<T> CompletionStage<T>
ExtendedStatisticRpcManager. invokeCommandOnAll(ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
<T> CompletionStage<T>
ExtendedStatisticRpcManager. invokeCommandStaggered(Collection<Address> targets, ReplicableCommand command, ResponseCollector<T> collector, RpcOptions rpcOptions)
Map<Address,Response>
ExtendedStatisticRpcManager. invokeRemotely(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options)
CompletableFuture<Map<Address,Response>>
ExtendedStatisticRpcManager. invokeRemotelyAsync(Collection<Address> recipients, ReplicableCommand rpc, RpcOptions options)
void
ExtendedStatisticRpcManager. sendTo(Address destination, ReplicableCommand command, DeliverOrder deliverOrder)
void
ExtendedStatisticRpcManager. sendToAll(ReplicableCommand command, DeliverOrder deliverOrder)
void
ExtendedStatisticRpcManager. sendToMany(Collection<Address> destinations, ReplicableCommand command, DeliverOrder deliverOrder)
Method parameters in org.infinispan.stats.wrappers with type arguments of type ReplicableCommand Modifier and Type Method Description <T> CompletionStage<T>
ExtendedStatisticRpcManager. invokeCommands(Collection<Address> targets, Function<Address,ReplicableCommand> commandGenerator, ResponseCollector<T> collector, RpcOptions rpcOptions)
Map<Address,Response>
ExtendedStatisticRpcManager. invokeRemotely(Map<Address,ReplicableCommand> rpcs, RpcOptions options)
-
Uses of ReplicableCommand in org.infinispan.stream.impl
Classes in org.infinispan.stream.impl that implement ReplicableCommand Modifier and Type Class Description class
StreamIteratorCloseCommand
Stream iterator command that unregisters an iterator so it doesn't consume memory unnecessarilyclass
StreamIteratorNextCommand
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.class
StreamIteratorRequestCommand<K>
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.class
StreamRequestCommand<K>
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.class
StreamResponseCommand<R>
Stream response command used to handle returning intermediate or final responses from the remote node -
Uses of ReplicableCommand in org.infinispan.topology
Classes in org.infinispan.topology that implement ReplicableCommand Modifier and Type Class Description class
CacheTopologyControlCommand
A control command for all cache membership/rebalance operations.class
HeartBeatCommand
A hear-beat command used to ping members inClusterTopologyManagerImpl.confirmMembersAvailable()
.Methods in org.infinispan.topology with parameters of type ReplicableCommand Modifier and Type Method Description <T> T
LocalTopologyManagerImpl. executeOnCoordinatorRetry(ReplicableCommand command, int viewId)
-
Uses of ReplicableCommand in org.infinispan.util
Methods in org.infinispan.util that return types with arguments of type ReplicableCommand Modifier and Type Method Description Collection<Class<? extends ReplicableCommand>>
ModuleProperties. moduleCommands()
Collection<Class<? extends ReplicableCommand>>
ModuleProperties. moduleOnlyReplicableCommands()
-
Uses of ReplicableCommand in org.infinispan.util.concurrent.locks
Subinterfaces of ReplicableCommand in org.infinispan.util.concurrent.locks Modifier and Type Interface Description interface
RemoteLockCommand
Simple interface to extract all the keys that may need to be locked.interface
TransactionalRemoteLockCommand
Simple interface to extract all the keys that may need to be locked for transactional commands. -
Uses of ReplicableCommand in org.infinispan.util.logging
Methods in org.infinispan.util.logging with parameters of type ReplicableCommand Modifier and Type Method Description void
Log_$logger. errorSendingResponse(long requestId, org.jgroups.Address origin, ReplicableCommand command)
void
Log. errorSendingResponse(long requestId, org.jgroups.Address origin, ReplicableCommand command)
void
Log_$logger. exceptionHandlingCommand(ReplicableCommand cmd, Throwable t)
void
Log. exceptionHandlingCommand(ReplicableCommand cmd, Throwable t)
void
Log_$logger. shutdownHandlingCommand(ReplicableCommand command)
void
Log. shutdownHandlingCommand(ReplicableCommand command)
-
Uses of ReplicableCommand in org.infinispan.xsite
Classes in org.infinispan.xsite that implement ReplicableCommand Modifier and Type Class Description class
SingleXSiteRpcCommand
RPC command to replicate cache operations (such as put, remove, replace, etc.) to the backup site.class
XSiteAdminCommand
Command used for handling XSiteReplication administrative operations.class
XSiteReplicateCommand
Abstract class to invoke RPC on the remote site. -
Uses of ReplicableCommand in org.infinispan.xsite.statetransfer
Classes in org.infinispan.xsite.statetransfer that implement ReplicableCommand Modifier and Type Class Description class
XSiteStatePushCommand
Wraps the state to be sent to another siteclass
XSiteStateTransferControlCommand
Command used to control the state transfer between sites.
-