Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Interface and 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
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
Visitor s, such as CommandInterceptor s. |
Modifier and Type | Class and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
ReplicableCommand |
RemoteCommandsFactory.fromStream(byte id,
Object[] parameters,
byte type)
Creates an un-initialized command.
|
Modifier and Type | Method and Description |
---|---|
SingleRpcCommand |
CommandsFactoryImpl.buildSingleRpcCommand(ReplicableCommand call) |
SingleRpcCommand |
CommandsFactory.buildSingleRpcCommand(ReplicableCommand call)
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
|
void |
CommandsFactoryImpl.initializeReplicableCommand(ReplicableCommand c,
boolean isRemote) |
void |
CommandsFactory.initializeReplicableCommand(ReplicableCommand command,
boolean isRemote)
Initializes a
ReplicableCommand read from a data stream with components specific
to the target cache instance. |
Modifier and Type | Method and Description |
---|---|
MultipleRpcCommand |
CommandsFactoryImpl.buildReplicateCommand(List<ReplicableCommand> toReplicate) |
MultipleRpcCommand |
CommandsFactory.buildReplicateCommand(List<ReplicableCommand> toReplicate)
Builds an RpcCommand "envelope" containing multiple ReplicableCommands
|
Modifier and Type | Class and Description |
---|---|
class |
LockControlCommand
LockControlCommand is a command that enables distributed locking across infinispan nodes.
|
Modifier and Type | Class and 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,R> |
class |
ReadWriteManyCommand<K,V,R> |
class |
ReadWriteManyEntriesCommand<K,V,R> |
class |
WriteOnlyKeyCommand<K,V> |
class |
WriteOnlyKeyValueCommand<K,V> |
class |
WriteOnlyManyCommand<K,V> |
class |
WriteOnlyManyEntriesCommand<K,V> |
Modifier and Type | Method and Description |
---|---|
ReplicableCommand |
ModuleCommandFactory.fromStream(byte commandId,
Object[] args)
Construct and initialize a
ReplicableCommand based on the command
id and argument array passed in. |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
void |
ModuleCommandInitializer.initializeReplicableCommand(ReplicableCommand c,
boolean isRemote)
Initializes a command constructed using
ModuleCommandFactory#fromStream(byte) with
necessary named-cache-specific components. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDataCommand |
class |
DistributedExecuteCommand<V>
DistributedExecuteCommand is used to migrate Callable and execute it in remote JVM.
|
class |
EntrySetCommand<K,V>
Command implementation for
Map.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 by
Map.get(Object) and
Map.containsKey(Object) operations |
class |
KeySetCommand<K,V>
Command implementation for
Map.keySet() functionality. |
class |
MapCombineCommand<KIn,VIn,KOut,VOut>
|
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
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheRpcCommand
The
RpcManager only replicates commands wrapped in a CacheRpcCommand . |
Modifier and Type | Class and Description |
---|---|
class |
BaseRpcCommand |
class |
BaseRpcInvokingCommand
Base class for RPC commands.
|
class |
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 |
LocalFlagAffectedRpcCommand |
class |
MultipleRpcCommand
Command that implements cluster replication logic.
|
class |
SingleRpcCommand
Similar to
MultipleRpcCommand , but it only aggregates a single command for
replication. |
Modifier and Type | Method and Description |
---|---|
ReplicableCommand |
SingleRpcCommand.getCommand() |
ReplicableCommand[] |
MultipleRpcCommand.getCommands() |
Modifier and Type | Method and Description |
---|---|
protected Object |
BaseRpcInvokingCommand.processVisitableCommand(ReplicableCommand cacheCommand) |
Constructor and Description |
---|
SingleRpcCommand(String cacheName,
ReplicableCommand command) |
Constructor and Description |
---|
MultipleRpcCommand(List<ReplicableCommand> modifications,
String cacheName) |
Modifier and Type | Class and 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.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TransactionBoundaryCommand
An transaction boundary command that allows the retrieval of an attached
GlobalTransaction |
Modifier and Type | Class and Description |
---|---|
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). |
Modifier and Type | Interface and Description |
---|---|
interface |
TotalOrderPrepareCommand
Interface with the utilities methods that the prepare command must have when Total Order based protocol is used
|
Modifier and Type | Class and 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.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataWriteCommand
Mixes features from DataCommand and WriteCommand
|
interface |
WriteCommand
A command that modifies the cache in some way
|
Modifier and Type | Class and Description |
---|---|
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 |
RemoveExpiredCommand
Removes an entry that is expired from memory
|
class |
ReplaceCommand |
Modifier and Type | Class and Description |
---|---|
class |
EntryRequestCommand<K,V,C>
Command sent to request entry iterator values for given segments.
|
class |
EntryResponseCommand<K,C>
Command sent to respond with entry values for given segments
|
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Class and Description |
---|---|
class |
ReplicableCommandManagerFunction
Replicable Command that runs the given Function passing the
EmbeddedCacheManager as an argument |
class |
ReplicableCommandRunnable
Replicable Command that runs the given Runnable
|
Modifier and Type | Method and Description |
---|---|
protected ReplicableCommand |
ReplicableCommandExternalizer.readCommandHeader(ObjectInput input) |
ReplicableCommand |
ReplicableCommandExternalizer.readObject(ObjectInput input) |
Modifier and Type | Method and Description |
---|---|
Set<Class<? extends ReplicableCommand>> |
ReplicableCommandExternalizer.getTypeClasses() |
Modifier and Type | Method and Description |
---|---|
protected void |
ReplicableCommandExternalizer.writeCommandHeader(ObjectOutput output,
ReplicableCommand command) |
protected void |
ReplicableCommandExternalizer.writeCommandParameters(ObjectOutput output,
ReplicableCommand command) |
void |
ReplicableCommandExternalizer.writeObject(ObjectOutput output,
ReplicableCommand command) |
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
protected List<ReplicableCommand> |
ReplicationQueueImpl.drainReplQueue()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationQueueImpl.add(ReplicableCommand job)
Deprecated.
|
void |
ReplicationQueue.add(ReplicableCommand job)
Deprecated.
Adds a new command to the replication queue.
|
Modifier and Type | Method and Description |
---|---|
void |
InboundInvocationHandler.handleFromCluster(Address origin,
ReplicableCommand command,
Reply reply,
DeliverOrder order)
Handles the
ReplicableCommand from other node belonging to local site. |
void |
GlobalInboundInvocationHandler.handleFromCluster(Address origin,
ReplicableCommand command,
Reply reply,
DeliverOrder order) |
protected void |
BasePerCacheInboundInvocationHandler.unexpectedDeliverMode(ReplicableCommand command,
DeliverOrder deliverOrder) |
Modifier and Type | Method and Description |
---|---|
Map<Address,Response> |
RpcManagerImpl.invokeRemotely(Map<Address,ReplicableCommand> rpcs,
RpcOptions options) |
Map<Address,Response> |
RpcManager.invokeRemotely(Map<Address,ReplicableCommand> rpcs,
RpcOptions options) |
Modifier and Type | Method and 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.
|
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Map<Address,Response> |
Transport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast)
Invokes an RPC call on other caches in the cluster.
|
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) |
Modifier and Type | Method and Description |
---|---|
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast) |
Map<Address,Response> |
Transport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast)
Deprecated.
|
Map<Address,Response> |
AbstractDelegatingTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Map<Address,Response> |
Transport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Modifier and Type | Method and Description |
---|---|
SingleResponseFuture |
CommandAwareRpcDispatcher.invokeRemoteCommand(org.jgroups.Address recipient,
ReplicableCommand command,
org.jgroups.blocks.ResponseMode mode,
long timeout,
DeliverOrder deliverOrder) |
CompletableFuture<org.jgroups.util.RspList<Response>> |
CommandAwareRpcDispatcher.invokeRemoteCommands(List<org.jgroups.Address> recipients,
ReplicableCommand command,
org.jgroups.blocks.ResponseMode mode,
long timeout,
org.jgroups.blocks.RspFilter filter,
DeliverOrder deliverOrder) |
Map<Address,Response> |
JGroupsTransport.invokeRemotely(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
CompletableFuture<Map<Address,Response>> |
JGroupsTransport.invokeRemotelyAsync(Collection<Address> recipients,
ReplicableCommand rpcCommand,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Modifier and Type | Method and Description |
---|---|
Map<Address,Response> |
JGroupsTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
boolean usePriorityQueue,
ResponseFilter responseFilter,
boolean totalOrder,
boolean anycast) |
Map<Address,Response> |
JGroupsTransport.invokeRemotely(Map<Address,ReplicableCommand> rpcCommands,
ResponseMode mode,
long timeout,
ResponseFilter responseFilter,
DeliverOrder deliverOrder,
boolean anycast) |
Modifier and Type | Method and Description |
---|---|
void |
JavaLog_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
JavaLog_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
void |
JavaLog_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
JavaLog_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Class and 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.
|
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
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.invokeRemotelyInFuture(Collection<Address> recipients,
ReplicableCommand rpc,
RpcOptions options,
NotifyingNotifiableFuture<Object> future) |
void |
ExtendedStatisticRpcManager.invokeRemotelyInFuture(NotifyingNotifiableFuture<Map<Address,Response>> future,
Collection<Address> recipients,
ReplicableCommand rpc,
RpcOptions options) |
Modifier and Type | Method and Description |
---|---|
Map<Address,Response> |
ExtendedStatisticRpcManager.invokeRemotely(Map<Address,ReplicableCommand> rpcs,
RpcOptions options) |
Modifier and Type | Class and Description |
---|---|
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
|
class |
StreamSegmentResponseCommand<R>
A stream response command taht also returns back suspected segments that need to be retried
|
Modifier and Type | Class and Description |
---|---|
class |
CacheTopologyControlCommand
A control command for all cache membership/rebalance operations.
|
Modifier and Type | Method and Description |
---|---|
void |
Log_$logger.exceptionHandlingCommand(ReplicableCommand arg0,
Throwable arg1) |
void |
Log_$logger.shutdownHandlingCommand(ReplicableCommand arg0) |
Modifier and Type | Method and Description |
---|---|
Collection<Class<? extends ReplicableCommand>> |
ModuleProperties.moduleCommands() |
Collection<Class<? extends ReplicableCommand>> |
ModuleProperties.moduleOnlyReplicableCommands() |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Class and 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.
|
Modifier and Type | Class and Description |
---|---|
class |
XSiteStatePushCommand
Wraps the state to be sent to another site
|
class |
XSiteStateTransferControlCommand
Command used to control the state transfer between sites.
|
Copyright © 2020 JBoss, a division of Red Hat. All rights reserved.