Package org.infinispan.commands
Interface CommandsFactory
-
- All Known Implementing Classes:
CommandsFactoryImpl
public interface CommandsFactory
A factory to build commands, initializing and injecting dependencies accordingly. Commands built for a specific, named cache instance cannot be reused on a different cache instance since most commands contain the cache name it was built for along with references to other named-cache scoped components.Commands returned by the various build*Command methods should be initialised sufficiently for local execution via the interceptor chain, with no calls to
initializeReplicableCommand(ReplicableCommand, boolean)
required. However, for remote execution, it's assumed that a command will be initialized viainitializeReplicableCommand(ReplicableCommand, boolean)
before being invoked.Note,
InitializableCommand
implementations should not rely on access to theComponentRegistry
in their constructors for local execution initialization as this leads to duplicated code. Instead implementations of this interface should callInitializableCommand.init(ComponentRegistry, boolean)
before returning the created command.- Since:
- 4.0
- Author:
- Manik Surtani, [email protected], Galder ZamarreƱo
-
-
Method Summary
-
-
-
Method Detail
-
buildPutKeyValueCommand
PutKeyValueCommand buildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet)
Builds a PutKeyValueCommand- Parameters:
key
- key to putvalue
- value to putsegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a PutKeyValueCommand
-
buildRemoveCommand
RemoveCommand buildRemoveCommand(Object key, Object value, int segment, long flagsBitSet)
Builds a RemoveCommand- Parameters:
key
- key to removevalue
- value to check for ina conditional remove, or null for an unconditional remove.segment
- the segment of the given keyflagsBitSet
- Command flags provided by cache- Returns:
- a RemoveCommand
-
buildInvalidateCommand
InvalidateCommand buildInvalidateCommand(long flagsBitSet, Object... keys)
Builds an InvalidateCommand- Parameters:
flagsBitSet
- Command flags provided by cachekeys
- keys to invalidate- Returns:
- an InvalidateCommand
-
buildInvalidateFromL1Command
InvalidateCommand buildInvalidateFromL1Command(long flagsBitSet, Collection<Object> keys)
Builds an InvalidateFromL1Command- Parameters:
flagsBitSet
- Command flags provided by cachekeys
- keys to invalidate- Returns:
- an InvalidateFromL1Command
-
buildInvalidateFromL1Command
InvalidateCommand buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys)
-
buildRemoveExpiredCommand
RemoveExpiredCommand buildRemoveExpiredCommand(Object key, Object value, int segment, Long lifespan, long flagsBitSet)
Builds an expired remove command that is used to remove only a specific entry when it expires via lifespan- Parameters:
key
- the key of the expired entryvalue
- the value of the entry when it was expiredsegment
- the segment of the given keylifespan
- the lifespan that expired from the commandflagsBitSet
- Command flags provided by cache- Returns:
- a RemovedExpiredCommand
-
buildRemoveExpiredCommand
RemoveExpiredCommand buildRemoveExpiredCommand(Object key, Object value, int segment, long flagsBitSet)
Builds an expired remove command that is used to remove only a specific entry when it expires via maxIdle- Parameters:
key
- the key of the expired entryvalue
- the value of the entry when it was expiredsegment
- the segment of the given keyflagsBitSet
- Command flags provided by cache- Returns:
- a RemovedExpiredCommand
-
buildReplaceCommand
ReplaceCommand buildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet)
Builds a ReplaceCommand- Parameters:
key
- key to replaceoldValue
- existing value to check for if conditional, null if unconditional.newValue
- value to replace withsegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a ReplaceCommand
-
buildComputeCommand
ComputeCommand buildComputeCommand(Object key, BiFunction mappingFunction, boolean computeIfPresent, int segment, Metadata metadata, long flagsBitSet)
Builds a ComputeCommand- Parameters:
key
- key to compute if this key is absentmappingFunction
- BiFunction for the key and the valuecomputeIfPresent
- flag to apply as computeIfPresent modesegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a ComputeCommand
-
buildComputeIfAbsentCommand
ComputeIfAbsentCommand buildComputeIfAbsentCommand(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet)
Builds a ComputeIfAbsentCommand- Parameters:
key
- key to compute if this key is absentmappingFunction
- mappingFunction for the keysegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a ComputeCommand
-
buildSizeCommand
SizeCommand buildSizeCommand(long flagsBitSet)
Builds a SizeCommand- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a SizeCommand
-
buildGetKeyValueCommand
GetKeyValueCommand buildGetKeyValueCommand(Object key, int segment, long flagsBitSet)
Builds a GetKeyValueCommand- Parameters:
key
- key to getsegment
- the segment of the given keyflagsBitSet
- Command flags provided by cache- Returns:
- a GetKeyValueCommand
-
buildGetCacheEntryCommand
GetCacheEntryCommand buildGetCacheEntryCommand(Object key, int segment, long flagsBitSet)
Builds a GetCacheEntryCommand- Parameters:
key
- key to getsegment
- the segment for the keyflagsBitSet
- Command flags provided by cache- Returns:
- a GetCacheEntryCommand
-
buildGetAllCommand
GetAllCommand buildGetAllCommand(Collection<?> keys, long flagsBitSet, boolean returnEntries)
Builds a GetAllCommand- Parameters:
keys
- keys to getflagsBitSet
- Command flags provided by cachereturnEntries
- boolean indicating whether entire cache entries are returned, otherwise return just the value parts- Returns:
- a GetKeyValueCommand
-
buildKeySetCommand
KeySetCommand buildKeySetCommand(long flagsBitSet)
Builds a KeySetCommand- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a KeySetCommand
-
buildEntrySetCommand
EntrySetCommand buildEntrySetCommand(long flagsBitSet)
Builds a EntrySetCommand- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a EntrySetCommand
-
buildPutMapCommand
PutMapCommand buildPutMapCommand(Map<?,?> map, Metadata metadata, long flagsBitSet)
Builds a PutMapCommand- Parameters:
map
- map containing key/value entries to putmetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a PutMapCommand
-
buildClearCommand
ClearCommand buildClearCommand(long flagsBitSet)
Builds a ClearCommand- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a ClearCommand
-
buildEvictCommand
EvictCommand buildEvictCommand(Object key, int segment, long flagsBitSet)
Builds an EvictCommand- Parameters:
key
- key to evictsegment
- the segment for the keyflagsBitSet
- Command flags provided by cache- Returns:
- an EvictCommand
-
buildPrepareCommand
PrepareCommand buildPrepareCommand(GlobalTransaction gtx, List<WriteCommand> modifications, boolean onePhaseCommit)
Builds a PrepareCommand- Parameters:
gtx
- global transaction associated with the preparemodifications
- list of modificationsonePhaseCommit
- is this a one-phase or two-phase transaction?- Returns:
- a PrepareCommand
-
buildVersionedPrepareCommand
VersionedPrepareCommand buildVersionedPrepareCommand(GlobalTransaction gtx, List<WriteCommand> modifications, boolean onePhase)
Builds a VersionedPrepareCommand- Parameters:
gtx
- global transaction associated with the preparemodifications
- list of modificationsonePhase
-- Returns:
- a VersionedPrepareCommand
-
buildCommitCommand
CommitCommand buildCommitCommand(GlobalTransaction gtx)
Builds a CommitCommand- Parameters:
gtx
- global transaction associated with the commit- Returns:
- a CommitCommand
-
buildVersionedCommitCommand
VersionedCommitCommand buildVersionedCommitCommand(GlobalTransaction gtx)
Builds a VersionedCommitCommand- Parameters:
gtx
- global transaction associated with the commit- Returns:
- a VersionedCommitCommand
-
buildRollbackCommand
RollbackCommand buildRollbackCommand(GlobalTransaction gtx)
Builds a RollbackCommand- Parameters:
gtx
- global transaction associated with the rollback- Returns:
- a RollbackCommand
-
initializeReplicableCommand
@Deprecated void initializeReplicableCommand(ReplicableCommand command, boolean isRemote)
Deprecated.since 11.0, please useCacheRpcCommand.invokeAsync(ComponentRegistry)
orGlobalRpcCommand.invokeAsync(GlobalComponentRegistry)
instead. to access any components required at invocation time.Initializes aReplicableCommand
read from a data stream with components specific to the target cache instance. Implementations should also be deep, in that if the command contains other commands, these should be recursed into.- Parameters:
command
- command to initialize. Cannot be null.isRemote
-
-
buildSingleRpcCommand
@Deprecated default SingleRpcCommand buildSingleRpcCommand(ReplicableCommand call)
Deprecated.since 11.0 usebuildSingleRpcCommand(VisitableCommand)
instead.Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand- Parameters:
call
- ReplicableCommand to include in the envelope- Returns:
- a SingleRpcCommand
-
buildSingleRpcCommand
SingleRpcCommand buildSingleRpcCommand(VisitableCommand command)
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand- Parameters:
command
- VisitableCommand to include in the envelope- Returns:
- a SingleRpcCommand
-
buildClusteredGetCommand
ClusteredGetCommand buildClusteredGetCommand(Object key, Integer segment, long flagsBitSet)
Builds a ClusteredGetCommand, which is a remote lookup command- Parameters:
key
- key to look upsegment
- the segment for the key or null if it should be computed on the remote nodeflagsBitSet
- Command flags provided by cache- Returns:
- a ClusteredGetCommand
-
buildClusteredGetAllCommand
ClusteredGetAllCommand buildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx)
Builds a ClusteredGetAllCommand, which is a remote lookup command- Parameters:
keys
- key to look upflagsBitSet
- Command flags provided by cache- Returns:
- a ClusteredGetAllCommand
-
buildLockControlCommand
LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx)
Builds a LockControlCommand to control explicit remote locking- Parameters:
keys
- keys to lockflagsBitSet
- Command flags provided by cachegtx
-- Returns:
- a LockControlCommand
-
buildLockControlCommand
LockControlCommand buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx)
Same asbuildLockControlCommand(Collection, long, GlobalTransaction)
but for locking a single key vs a collection of keys.
-
buildLockControlCommand
LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet)
-
buildConflictResolutionStartCommand
ConflictResolutionStartCommand buildConflictResolutionStartCommand(int topologyId, org.infinispan.commons.util.IntSet segments)
-
buildStateTransferCancelCommand
StateTransferCancelCommand buildStateTransferCancelCommand(int topologyId, org.infinispan.commons.util.IntSet segments)
-
buildStateTransferGetListenersCommand
StateTransferGetListenersCommand buildStateTransferGetListenersCommand(int topologyId)
-
buildStateTransferGetTransactionsCommand
StateTransferGetTransactionsCommand buildStateTransferGetTransactionsCommand(int topologyId, org.infinispan.commons.util.IntSet segments)
-
buildStateTransferStartCommand
StateTransferStartCommand buildStateTransferStartCommand(int topologyId, org.infinispan.commons.util.IntSet segments)
-
buildScatteredStateGetKeysCommand
ScatteredStateGetKeysCommand buildScatteredStateGetKeysCommand(int topologyId, org.infinispan.commons.util.IntSet segments)
-
buildScatteredStateConfirmRevokeCommand
ScatteredStateConfirmRevokedCommand buildScatteredStateConfirmRevokeCommand(int topologyId, org.infinispan.commons.util.IntSet segments)
-
buildStateResponseCommand
StateResponseCommand buildStateResponseCommand(int viewId, Collection<StateChunk> stateChunks, boolean applyState, boolean pushTransfer)
Builds a StateResponseCommand used for pushing cache entries to another node.
-
getCacheName
String getCacheName()
Retrieves the cache name this CommandFactory is set up to construct commands for.- Returns:
- the name of the cache this CommandFactory is set up to construct commands for.
-
buildGetInDoubtTransactionsCommand
GetInDoubtTransactionsCommand buildGetInDoubtTransactionsCommand()
Builds aGetInDoubtTransactionsCommand
.
-
buildTxCompletionNotificationCommand
TxCompletionNotificationCommand buildTxCompletionNotificationCommand(org.infinispan.commons.tx.XidImpl xid, GlobalTransaction globalTransaction)
Builds aTxCompletionNotificationCommand
.
-
buildGetInDoubtTxInfoCommand
GetInDoubtTxInfoCommand buildGetInDoubtTxInfoCommand()
- See Also:
GetInDoubtTxInfoCommand
-
buildCompleteTransactionCommand
CompleteTransactionCommand buildCompleteTransactionCommand(org.infinispan.commons.tx.XidImpl xid, boolean commit)
Builds a CompleteTransactionCommand command.- Parameters:
xid
- the xid identifying the transaction we want to complete.commit
- commit(true) or rollback(false)?
-
buildTxCompletionNotificationCommand
TxCompletionNotificationCommand buildTxCompletionNotificationCommand(long internalId)
- Parameters:
internalId
- the internal id identifying the transaction to be removed.- See Also:
TxCompletionNotificationCommand
-
buildXSiteStateTransferCancelSendCommand
XSiteStateTransferCancelSendCommand buildXSiteStateTransferCancelSendCommand(String siteName)
-
buildXSiteStateTransferClearStatusCommand
XSiteStateTransferClearStatusCommand buildXSiteStateTransferClearStatusCommand()
-
buildXSiteStateTransferFinishReceiveCommand
XSiteStateTransferFinishReceiveCommand buildXSiteStateTransferFinishReceiveCommand(String siteName)
-
buildXSiteStateTransferFinishSendCommand
XSiteStateTransferFinishSendCommand buildXSiteStateTransferFinishSendCommand(String siteName, boolean statusOk)
-
buildXSiteStateTransferRestartSendingCommand
XSiteStateTransferRestartSendingCommand buildXSiteStateTransferRestartSendingCommand(String siteName, int topologyId)
-
buildXSiteStateTransferStartReceiveCommand
XSiteStateTransferStartReceiveCommand buildXSiteStateTransferStartReceiveCommand()
-
buildXSiteStateTransferStartSendCommand
XSiteStateTransferStartSendCommand buildXSiteStateTransferStartSendCommand(String siteName, int topologyId)
-
buildXSiteStateTransferStatusRequestCommand
XSiteStateTransferStatusRequestCommand buildXSiteStateTransferStatusRequestCommand()
-
buildXSiteAmendOfflineStatusCommand
XSiteAmendOfflineStatusCommand buildXSiteAmendOfflineStatusCommand(String siteName, Integer afterFailures, Long minTimeToWait)
-
buildXSiteBringOnlineCommand
XSiteBringOnlineCommand buildXSiteBringOnlineCommand(String siteName)
-
buildXSiteOfflineStatusCommand
XSiteOfflineStatusCommand buildXSiteOfflineStatusCommand(String siteName)
-
buildXSiteStatusCommand
XSiteStatusCommand buildXSiteStatusCommand()
-
buildXSiteTakeOfflineCommand
XSiteTakeOfflineCommand buildXSiteTakeOfflineCommand(String siteName)
-
buildXSiteStatePushCommand
XSiteStatePushCommand buildXSiteStatePushCommand(XSiteState[] chunk, long timeoutMillis)
Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.- Parameters:
chunk
- the data chunktimeoutMillis
- timeout in milliseconds, for the retries in the receiver site.- Returns:
- the XSiteStatePushCommand created
-
buildSingleXSiteRpcCommand
SingleXSiteRpcCommand buildSingleXSiteRpcCommand(VisitableCommand command)
Builds SingleRpcCommand used to performVisitableCommand
on the backup site,- Parameters:
command
- the visitable command.- Returns:
- the SingleXSiteRpcCommand created
-
buildGetKeysInGroupCommand
GetKeysInGroupCommand buildGetKeysInGroupCommand(long flagsBitSet, Object groupName)
BuildsGetKeysInGroupCommand
used to fetch all the keys belonging to a group.- Parameters:
flagsBitSet
- Command flags provided by cachegroupName
- the group name.- Returns:
- the GetKeysInGroup created.
-
buildReadOnlyKeyCommand
<K,V,R> ReadOnlyKeyCommand<K,V,R> buildReadOnlyKeyCommand(Object key, Function<EntryView.ReadEntryView<K,V>,R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildReadOnlyManyCommand
<K,V,R> ReadOnlyManyCommand<K,V,R> buildReadOnlyManyCommand(Collection<?> keys, Function<EntryView.ReadEntryView<K,V>,R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildWriteOnlyKeyCommand
<K,V> WriteOnlyKeyCommand<K,V> buildWriteOnlyKeyCommand(Object key, Consumer<EntryView.WriteEntryView<K,V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildReadWriteKeyValueCommand
<K,V,T,R> ReadWriteKeyValueCommand<K,V,T,R> buildReadWriteKeyValueCommand(Object key, Object argument, BiFunction<T,EntryView.ReadWriteEntryView<K,V>,R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildReadWriteKeyCommand
<K,V,R> ReadWriteKeyCommand<K,V,R> buildReadWriteKeyCommand(Object key, Function<EntryView.ReadWriteEntryView<K,V>,R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildWriteOnlyManyEntriesCommand
<K,V,T> WriteOnlyManyEntriesCommand<K,V,T> buildWriteOnlyManyEntriesCommand(Map<?,?> arguments, BiConsumer<T,EntryView.WriteEntryView<K,V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildWriteOnlyKeyValueCommand
<K,V,T> WriteOnlyKeyValueCommand<K,V,T> buildWriteOnlyKeyValueCommand(Object key, Object argument, BiConsumer<T,EntryView.WriteEntryView<K,V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildWriteOnlyManyCommand
<K,V> WriteOnlyManyCommand<K,V> buildWriteOnlyManyCommand(Collection<?> keys, Consumer<EntryView.WriteEntryView<K,V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildReadWriteManyCommand
<K,V,R> ReadWriteManyCommand<K,V,R> buildReadWriteManyCommand(Collection<?> keys, Function<EntryView.ReadWriteEntryView<K,V>,R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildReadWriteManyEntriesCommand
<K,V,T,R> ReadWriteManyEntriesCommand<K,V,T,R> buildReadWriteManyEntriesCommand(Map<?,?> entries, BiFunction<T,EntryView.ReadWriteEntryView<K,V>,R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildTxReadOnlyKeyCommand
<K,V,R> TxReadOnlyKeyCommand<K,V,R> buildTxReadOnlyKeyCommand(Object key, Function<EntryView.ReadEntryView<K,V>,R> f, List<Mutation<K,V,?>> mutations, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildTxReadOnlyManyCommand
<K,V,R> TxReadOnlyManyCommand<K,V,R> buildTxReadOnlyManyCommand(Collection<?> keys, List<List<Mutation<K,V,?>>> mutations, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion)
-
buildBackupAckCommand
BackupAckCommand buildBackupAckCommand(long id, int topologyId)
-
buildBackupMultiKeyAckCommand
BackupMultiKeyAckCommand buildBackupMultiKeyAckCommand(long id, int segment, int topologyId)
-
buildExceptionAckCommand
ExceptionAckCommand buildExceptionAckCommand(long id, Throwable throwable, int topologyId)
-
buildInvalidateVersionsCommand
InvalidateVersionsCommand buildInvalidateVersionsCommand(int topologyId, Object[] keys, int[] topologyIds, long[] versions, boolean removed)
-
buildRevokeBiasCommand
RevokeBiasCommand buildRevokeBiasCommand(Address ackTarget, long id, int topologyId, Collection<Object> keys)
-
buildRenewBiasCommand
RenewBiasCommand buildRenewBiasCommand(Object[] keys)
-
buildSingleKeyBackupWriteCommand
SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand()
-
buildSingleKeyFunctionalBackupWriteCommand
SingleKeyFunctionalBackupWriteCommand buildSingleKeyFunctionalBackupWriteCommand()
-
buildPutMapBackupWriteCommand
PutMapBackupWriteCommand buildPutMapBackupWriteCommand()
-
buildMultiEntriesFunctionalBackupWriteCommand
MultiEntriesFunctionalBackupWriteCommand buildMultiEntriesFunctionalBackupWriteCommand()
-
buildMultiKeyFunctionalBackupWriteCommand
MultiKeyFunctionalBackupWriteCommand buildMultiKeyFunctionalBackupWriteCommand()
-
buildBackupNoopCommand
BackupNoopCommand buildBackupNoopCommand()
-
buildKeyReductionPublisherCommand
<K,R> ReductionPublisherRequestCommand<K> buildKeyReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, Function<? super org.reactivestreams.Publisher<K>,? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer)
-
buildEntryReductionPublisherCommand
<K,V,R> ReductionPublisherRequestCommand<K> buildEntryReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer)
-
buildInitialPublisherCommand
<K,I,R> InitialPublisherCommand<K,I,R> buildInitialPublisherCommand(String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>,? extends org.reactivestreams.Publisher<R>> transformer)
-
buildNextPublisherCommand
NextPublisherCommand buildNextPublisherCommand(String requestId)
-
buildCancelPublisherCommand
CancelPublisherCommand buildCancelPublisherCommand(String requestId)
-
buildMultiClusterEventCommand
<K,V> MultiClusterEventCommand<K,V> buildMultiClusterEventCommand(Map<UUID,Collection<ClusterEvent<K,V>>> events)
-
buildCheckTransactionRpcCommand
CheckTransactionRpcCommand buildCheckTransactionRpcCommand(Collection<GlobalTransaction> globalTransactions)
-
buildTouchCommand
TouchCommand buildTouchCommand(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet)
-
buildIracClearKeysCommand
IracClearKeysCommand buildIracClearKeysCommand()
-
buildIracCleanupKeyCommand
IracCleanupKeysCommand buildIracCleanupKeyCommand(Collection<? extends IracManagerKeyInfo> state)
-
buildIracTombstoneCleanupCommand
IracTombstoneCleanupCommand buildIracTombstoneCleanupCommand(int maxCapacity)
-
buildIracMetadataRequestCommand
IracMetadataRequestCommand buildIracMetadataRequestCommand(int segment, IracEntryVersion versionSeen)
-
buildIracRequestStateCommand
IracRequestStateCommand buildIracRequestStateCommand(org.infinispan.commons.util.IntSet segments)
-
buildIracStateResponseCommand
IracStateResponseCommand buildIracStateResponseCommand(int capacity)
-
buildIracPutKeyValueCommand
IracPutKeyValueCommand buildIracPutKeyValueCommand(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata)
-
buildIracTouchCommand
IracTouchKeyCommand buildIracTouchCommand(Object key)
-
buildIracUpdateVersionCommand
IracUpdateVersionCommand buildIracUpdateVersionCommand(Map<Integer,IracEntryVersion> segmentsVersion)
-
buildXSiteAutoTransferStatusCommand
XSiteAutoTransferStatusCommand buildXSiteAutoTransferStatusCommand(String site)
-
buildXSiteSetStateTransferModeCommand
XSiteSetStateTransferModeCommand buildXSiteSetStateTransferModeCommand(String site, org.infinispan.configuration.cache.XSiteStateTransferMode mode)
-
buildIracTombstoneRemoteSiteCheckCommand
IracTombstoneRemoteSiteCheckCommand buildIracTombstoneRemoteSiteCheckCommand(List<Object> keys)
-
buildIracTombstoneStateResponseCommand
IracTombstoneStateResponseCommand buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo> state)
-
buildIracTombstonePrimaryCheckCommand
IracTombstonePrimaryCheckCommand buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo> tombstones)
-
buildIracPutManyCommand
IracPutManyCommand buildIracPutManyCommand(int capacity)
-
-