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.control org.infinispan.commands.functional 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.expiration org.infinispan.commands.remote.recovery org.infinispan.commands.triangle org.infinispan.commands.tx Commands that represent transactional lifecycle transitions.org.infinispan.commands.tx.totalorder org.infinispan.commands.write Commands that alter the state of the cache.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.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.statetransfer Transfer of state to new caches in a cluster.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 SingleRpcCommand
CommandsFactory. buildSingleRpcCommand(ReplicableCommand call)
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommandSingleRpcCommand
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.control
Classes in org.infinispan.commands.control that implement ReplicableCommand Modifier and Type Class Description class
LockControlCommand
LockControlCommand is a command that enables distributed locking across infinispan nodes. -
Uses of ReplicableCommand in org.infinispan.commands.functional
Classes in org.infinispan.commands.functional that implement ReplicableCommand Modifier and Type Class Description class
AbstractWriteKeyCommand<K,V>
class
AbstractWriteManyCommand<K,V>
class
ReadOnlyKeyCommand<K,V,R>
class
ReadOnlyManyCommand<K,V,R>
class
ReadWriteKeyCommand<K,V,R>
class
ReadWriteKeyValueCommand<K,V,T,R>
class
ReadWriteManyCommand<K,V,R>
class
ReadWriteManyEntriesCommand<K,V,T,R>
class
TxReadOnlyKeyCommand<K,V,R>
class
TxReadOnlyManyCommand<K,V,R>
class
WriteOnlyKeyCommand<K,V>
class
WriteOnlyKeyValueCommand<K,V,T>
class
WriteOnlyManyCommand<K,V>
class
WriteOnlyManyEntriesCommand<K,V,T>
-
Uses of ReplicableCommand in org.infinispan.commands.module
Methods in org.infinispan.commands.module that return ReplicableCommand Modifier and Type Method Description ReplicableCommand
ModuleCommandFactory. fromStream(byte commandId)
Construct and initialize aReplicableCommand
based on the command id.Methods in org.infinispan.commands.module that return types with arguments of type ReplicableCommand Modifier and Type Method Description 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 Modifier and Type Method Description void
ModuleCommandInitializer. initializeReplicableCommand(ReplicableCommand c, boolean isRemote)
Initializes a command constructed usingModuleCommandFactory.fromStream(byte)
with necessary named-cache-specific components. -
Uses of ReplicableCommand in org.infinispan.commands.read
Classes in org.infinispan.commands.read that implement ReplicableCommand Modifier and Type Class Description class
AbstractDataCommand
class
AbstractLocalCommand
Abstract classclass
DistributedExecuteCommand<V>
DistributedExecuteCommand is used to migrate Callable and execute it in remote JVM.class
EntrySetCommand<K,V>
Command implementation forMap.entrySet()
functionality.class
GetAllCommand
Retrieves multiple entries at once.class
GetCacheEntryCommand
Used to fetch a full CacheEntry rather than just the value.class
GetKeyValueCommand
Implements functionality defined byMap.get(Object)
andMap.containsKey(Object)
operationsclass
KeySetCommand<K,V>
Command implementation forMap.keySet()
functionality.class
SizeCommand
Command to calculate the size of the cache -
Uses of ReplicableCommand in org.infinispan.commands.remote
Subinterfaces of ReplicableCommand in org.infinispan.commands.remote Modifier and Type Interface Description interface
CacheRpcCommand
TheRpcManager
only replicates commands wrapped in aCacheRpcCommand
.Classes in org.infinispan.commands.remote that implement ReplicableCommand Modifier and Type Class Description class
BaseClusteredReadCommand
class
BaseRpcCommand
class
BaseRpcInvokingCommand
Deprecated.Since 9.0, it will be removed soonclass
ClusteredGetAllCommand<K,V>
Issues a remote getAll call.class
ClusteredGetCommand
Issues a remote get call.class
GetKeysInGroupCommand
VisitableCommand
that fetches the keys belonging to a group.class
RenewBiasCommand
class
RevokeBiasCommand
Informs node that it is not allowed to serve reads from the local record anymore.class
SingleRpcCommand
Aggregates a single command for replication.Methods in org.infinispan.commands.remote that return ReplicableCommand Modifier and Type Method Description ReplicableCommand
SingleRpcCommand. getCommand()
Methods in org.infinispan.commands.remote with parameters of type ReplicableCommand Modifier and Type Method Description protected Object
BaseRpcInvokingCommand. processVisitableCommand(ReplicableCommand cacheCommand)
Deprecated.protected CompletableFuture<Object>
BaseRpcInvokingCommand. processVisitableCommandAsync(ReplicableCommand cacheCommand)
Deprecated.Constructors in org.infinispan.commands.remote with parameters of type ReplicableCommand Constructor Description SingleRpcCommand(ByteString cacheName, ReplicableCommand command)
-
Uses of ReplicableCommand in org.infinispan.commands.remote.expiration
Classes in org.infinispan.commands.remote.expiration that implement ReplicableCommand Modifier and Type Class Description class
RetrieveLastAccessCommand
Command that when invoked will retrieve the last access time from an entry without updating itclass
UpdateLastAccessCommand
Command that will update the last access time for an entry given the specific time -
Uses of ReplicableCommand in org.infinispan.commands.remote.recovery
Classes in org.infinispan.commands.remote.recovery that implement ReplicableCommand Modifier and Type Class Description 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.triangle
Classes in org.infinispan.commands.triangle that implement ReplicableCommand Modifier and Type Class Description class
BackupWriteCommand
A write operation sent from the primary owner to the backup owners.class
MultiEntriesFunctionalBackupWriteCommand
class
MultiKeyFunctionalBackupWriteCommand
class
PutMapBackupWriteCommand
ABackupWriteCommand
implementation forPutMapCommand
.class
SingleKeyBackupWriteCommand
A single keyBackupWriteCommand
for single key non-functional commands.class
SingleKeyFunctionalBackupWriteCommand
A single keyBackupWriteCommand
for single key functional commands. -
Uses of ReplicableCommand in org.infinispan.commands.tx
Subinterfaces of ReplicableCommand in org.infinispan.commands.tx Modifier and Type Interface Description interface
TransactionBoundaryCommand
An transaction boundary command that allows the retrieval of an attachedGlobalTransaction
Classes in org.infinispan.commands.tx that implement ReplicableCommand Modifier and Type Class Description class
AbstractTransactionBoundaryCommand
An abstract transaction boundary command that holds a reference to aGlobalTransaction
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 aCommitCommand
except that version information is also carried by this command, used by optimistically transactional caches making use of write skew checking when usingIsolationLevel.REPEATABLE_READ
.class
VersionedPrepareCommand
Same asPrepareCommand
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.tx.totalorder
Subinterfaces of ReplicableCommand in org.infinispan.commands.tx.totalorder Modifier and Type Interface Description interface
TotalOrderPrepareCommand
Interface with the utilities methods that the prepare command must have when Total Order based protocol is usedClasses in org.infinispan.commands.tx.totalorder that implement ReplicableCommand Modifier and Type Class Description class
TotalOrderCommitCommand
Commit Command used in the 2nd phase of 2PC.class
TotalOrderNonVersionedPrepareCommand
Command corresponding to the 1st phase of 2PC when Total Order based protocol is used.class
TotalOrderRollbackCommand
The 2nd phase command of 2PC, used when a transaction must be aborted.class
TotalOrderVersionedCommitCommand
Command corresponding to the 2nd phase of 2PC.class
TotalOrderVersionedPrepareCommand
Command corresponding to the 1st phase of 2PC when Total Order based protocol is used. -
Uses of ReplicableCommand in org.infinispan.commands.write
Subinterfaces of ReplicableCommand in org.infinispan.commands.write Modifier and Type Interface Description interface
DataWriteCommand
Mixes features from DataCommand and WriteCommandinterface
WriteCommand
A command that modifies the cache in some wayClasses in org.infinispan.commands.write that implement ReplicableCommand Modifier and Type Class Description class
AbstractDataWriteCommand
Stuff common to WriteCommandsclass
ApplyDeltaCommand
Deprecated.since 9.1class
BackupAckCommand
A command that represents an acknowledge sent by a backup owner to the originator.class
BackupMultiKeyAckCommand
A command that represents an acknowledge sent by a backup owner to the originator.class
ClearCommand
class
ComputeCommand
class
ComputeIfAbsentCommand
class
EvictCommand
class
ExceptionAckCommand
A command that represents an exception acknowledge sent by any owner.class
InvalidateCommand
Removes an entry from memory.class
InvalidateL1Command
Invalidates an entry in a L1 cache (used with DIST mode)class
InvalidateVersionsCommand
Must beVisitableCommand
as we want to catch it in persistence handling etc.class
PutKeyValueCommand
Implements functionality defined byBasicCache.put(Object, Object)
class
PutMapCommand
class
RemoveCommand
class
RemoveExpiredCommand
Removes an entry that is expired from memoryclass
ReplaceCommand
-
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.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.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.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.
-