Package org.infinispan.commands
Class CommandsFactoryImpl
java.lang.Object
org.infinispan.commands.CommandsFactoryImpl
- All Implemented Interfaces:
CommandsFactory
- Since:
- 4.0
- Author:
- Mircea.Markus@jboss.com, Galder ZamarreƱo, Sanne Grinovero <sanne@hibernate.org> (C) 2011 Red Hat Inc.
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionorg.infinispan.commands.write.BackupAckCommand
buildBackupAckCommand
(long id, int topologyId) org.infinispan.commands.write.BackupMultiKeyAckCommand
buildBackupMultiKeyAckCommand
(long id, int segment, int topologyId) org.infinispan.commands.triangle.BackupNoopCommand
org.infinispan.reactive.publisher.impl.commands.batch.CancelPublisherCommand
buildCancelPublisherCommand
(String requestId) org.infinispan.commands.remote.CheckTransactionRpcCommand
buildCheckTransactionRpcCommand
(Collection<GlobalTransaction> globalTransactions) org.infinispan.commands.write.ClearCommand
buildClearCommand
(long flagsBitSet) Builds a ClearCommandorg.infinispan.commands.remote.ClusteredGetAllCommand
buildClusteredGetAllCommand
(List<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a ClusteredGetAllCommand, which is a remote lookup commandorg.infinispan.commands.remote.ClusteredGetCommand
buildClusteredGetCommand
(Object key, Integer segment, long flagsBitSet) Builds a ClusteredGetCommand, which is a remote lookup commandorg.infinispan.commands.tx.CommitCommand
Builds a CommitCommandorg.infinispan.commands.remote.recovery.CompleteTransactionCommand
buildCompleteTransactionCommand
(XidImpl xid, boolean commit) Builds a CompleteTransactionCommand command.org.infinispan.commands.write.ComputeCommand
buildComputeCommand
(Object key, BiFunction mappingFunction, boolean computeIfPresent, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeCommandorg.infinispan.commands.write.ComputeIfAbsentCommand
buildComputeIfAbsentCommand
(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeIfAbsentCommandorg.infinispan.commands.statetransfer.ConflictResolutionStartCommand
buildConflictResolutionStartCommand
(int topologyId, IntSet segments) <K,
V, R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand <K> buildEntryReductionPublisherCommand
(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) org.infinispan.commands.read.EntrySetCommand
buildEntrySetCommand
(long flagsBitSet) Builds a EntrySetCommandorg.infinispan.commands.write.EvictCommand
buildEvictCommand
(Object key, int segment, long flagsBitSet) Builds an EvictCommandorg.infinispan.commands.write.ExceptionAckCommand
buildExceptionAckCommand
(long id, Throwable throwable, int topologyId) org.infinispan.commands.read.GetAllCommand
buildGetAllCommand
(Collection<?> keys, long flagsBitSet, boolean returnEntries) Builds a GetAllCommandorg.infinispan.commands.read.GetCacheEntryCommand
buildGetCacheEntryCommand
(Object key, int segment, long flagsBitSet) Builds a GetCacheEntryCommandorg.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
Builds aGetInDoubtTransactionsCommand
.org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
org.infinispan.commands.read.GetKeyValueCommand
buildGetKeyValueCommand
(Object key, int segment, long flagsBitSet) Builds a GetKeyValueCommand<K,
I, R> org.infinispan.reactive.publisher.impl.commands.batch.InitialPublisherCommand <K, I, R> buildInitialPublisherCommand
(String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>, ? extends org.reactivestreams.Publisher<R>> transformer) org.infinispan.commands.write.InvalidateCommand
buildInvalidateCommand
(long flagsBitSet, Object... keys) Builds an InvalidateCommandorg.infinispan.commands.write.InvalidateCommand
buildInvalidateFromL1Command
(long flagsBitSet, Collection<Object> keys) Builds an InvalidateFromL1Commandorg.infinispan.commands.write.InvalidateCommand
buildInvalidateFromL1Command
(Address origin, long flagsBitSet, Collection<Object> keys) org.infinispan.commands.write.InvalidateVersionsCommand
buildInvalidateVersionsCommand
(int topologyId, Object[] keys, int[] topologyIds, long[] versions, boolean removed) org.infinispan.commands.irac.IracCleanupKeysCommand
buildIracCleanupKeyCommand
(Collection<? extends IracManagerKeyInfo> state) org.infinispan.commands.irac.IracMetadataRequestCommand
buildIracMetadataRequestCommand
(int segment, IracEntryVersion versionSeen) org.infinispan.commands.write.IracPutKeyValueCommand
buildIracPutKeyValueCommand
(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata) buildIracPutManyCommand
(int capacity) org.infinispan.commands.irac.IracRequestStateCommand
buildIracRequestStateCommand
(IntSet segments) org.infinispan.commands.irac.IracStateResponseCommand
buildIracStateResponseCommand
(int capacity) org.infinispan.commands.irac.IracTombstoneCleanupCommand
buildIracTombstoneCleanupCommand
(int maxCapacity) org.infinispan.commands.irac.IracTombstonePrimaryCheckCommand
org.infinispan.commands.irac.IracTombstoneRemoteSiteCheckCommand
org.infinispan.commands.irac.IracTombstoneStateResponseCommand
org.infinispan.commands.irac.IracUpdateVersionCommand
buildIracUpdateVersionCommand
(Map<Integer, IracEntryVersion> segmentsVersion) <K,
R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand <K> buildKeyReductionPublisherCommand
(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) org.infinispan.commands.read.KeySetCommand
buildKeySetCommand
(long flagsBitSet) Builds a KeySetCommandorg.infinispan.commands.control.LockControlCommand
buildLockControlCommand
(Object key, long flagsBitSet, GlobalTransaction gtx) Same asCommandsFactory.buildLockControlCommand(Collection, long, GlobalTransaction)
but for locking a single key vs a collection of keys.org.infinispan.commands.control.LockControlCommand
buildLockControlCommand
(Collection<?> keys, long flagsBitSet) org.infinispan.commands.control.LockControlCommand
buildLockControlCommand
(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a LockControlCommand to control explicit remote locking<K,
V> MultiClusterEventCommand <K, V> buildMultiClusterEventCommand
(Map<UUID, Collection<ClusterEvent<K, V>>> events) org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
org.infinispan.reactive.publisher.impl.commands.batch.NextPublisherCommand
buildNextPublisherCommand
(String requestId) org.infinispan.commands.tx.PrepareCommand
buildPrepareCommand
(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhaseCommit) Builds a PrepareCommandorg.infinispan.commands.write.PutKeyValueCommand
buildPutKeyValueCommand
(Object key, Object value, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) org.infinispan.commands.triangle.PutMapBackupWriteCommand
org.infinispan.commands.write.PutMapCommand
buildPutMapCommand
(Map<?, ?> map, Metadata metadata, long flagsBitSet) Builds a PutMapCommand<K,
V, R> org.infinispan.commands.functional.ReadOnlyKeyCommand <K, V, R> buildReadOnlyKeyCommand
(Object key, Function<EntryView.ReadEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> org.infinispan.commands.functional.ReadOnlyManyCommand <K, V, R> buildReadOnlyManyCommand
(Collection<?> keys, Function<EntryView.ReadEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> org.infinispan.commands.functional.ReadWriteKeyCommand <K, V, R> buildReadWriteKeyCommand
(Object key, Function<EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T, R>
org.infinispan.commands.functional.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) <K,
V, R> org.infinispan.commands.functional.ReadWriteManyCommand <K, V, R> buildReadWriteManyCommand
(Collection<?> keys, Function<EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T, R>
org.infinispan.commands.functional.ReadWriteManyEntriesCommand<K, V, T, R> buildReadWriteManyEntriesCommand
(Map<?, ?> entries, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) org.infinispan.commands.write.RemoveCommand
buildRemoveCommand
(Object key, Object value, int segment, long flagsBitSet, boolean returnEntry) org.infinispan.commands.write.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 maxIdleorg.infinispan.commands.write.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 lifespanorg.infinispan.commands.remote.RenewBiasCommand
buildRenewBiasCommand
(Object[] keys) org.infinispan.commands.write.ReplaceCommand
buildReplaceCommand
(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) Builds a ReplaceCommandorg.infinispan.commands.remote.RevokeBiasCommand
buildRevokeBiasCommand
(Address ackTarget, long id, int topologyId, Collection<Object> keys) org.infinispan.commands.tx.RollbackCommand
Builds a RollbackCommandorg.infinispan.commands.statetransfer.ScatteredStateConfirmRevokedCommand
buildScatteredStateConfirmRevokeCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.ScatteredStateGetKeysCommand
buildScatteredStateGetKeysCommand
(int topologyId, IntSet segments) org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
org.infinispan.commands.remote.SingleRpcCommand
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommandorg.infinispan.xsite.SingleXSiteRpcCommand
Builds SingleRpcCommand used to performVisitableCommand
on the backup site,org.infinispan.commands.read.SizeCommand
buildSizeCommand
(IntSet segments, long flagsBitSet) Builds a SizeCommandorg.infinispan.commands.statetransfer.StateResponseCommand
buildStateResponseCommand
(int topologyId, Collection<org.infinispan.statetransfer.StateChunk> stateChunks, boolean applyState, boolean pushTransfer) Builds a StateResponseCommand used for pushing cache entries to another node.org.infinispan.commands.statetransfer.StateTransferCancelCommand
buildStateTransferCancelCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferGetListenersCommand
buildStateTransferGetListenersCommand
(int topologyId) org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommand
buildStateTransferGetTransactionsCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferStartCommand
buildStateTransferStartCommand
(int topologyId, IntSet segments) buildTouchCommand
(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet) org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
buildTxCompletionNotificationCommand
(long internalId) org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
buildTxCompletionNotificationCommand
(XidImpl xid, GlobalTransaction globalTransaction) Builds aTxCompletionNotificationCommand
.<K,
V, R> org.infinispan.commands.functional.TxReadOnlyKeyCommand <K, V, R> buildTxReadOnlyKeyCommand
(Object key, Function<EntryView.ReadEntryView<K, V>, R> f, List<org.infinispan.commands.functional.Mutation<K, V, ?>> mutations, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> org.infinispan.commands.functional.TxReadOnlyManyCommand <K, V, R> buildTxReadOnlyManyCommand
(Collection<?> keys, List<List<org.infinispan.commands.functional.Mutation<K, V, ?>>> mutations, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) org.infinispan.commands.tx.VersionedCommitCommand
Builds a VersionedCommitCommandorg.infinispan.commands.tx.VersionedPrepareCommand
buildVersionedPrepareCommand
(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhase) Builds a VersionedPrepareCommand<K,
V> org.infinispan.commands.functional.WriteOnlyKeyCommand <K, V> buildWriteOnlyKeyCommand
(Object key, Consumer<EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T> org.infinispan.commands.functional.WriteOnlyKeyValueCommand <K, V, T> buildWriteOnlyKeyValueCommand
(Object key, Object argument, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V> org.infinispan.commands.functional.WriteOnlyManyCommand <K, V> buildWriteOnlyManyCommand
(Collection<?> keys, Consumer<EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T> org.infinispan.commands.functional.WriteOnlyManyEntriesCommand <K, V, T> buildWriteOnlyManyEntriesCommand
(Map<?, ?> arguments, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) buildXSiteAmendOfflineStatusCommand
(String siteName, Integer afterFailures, Long minTimeToWait) buildXSiteBringOnlineCommand
(String siteName) buildXSiteOfflineStatusCommand
(String siteName) buildXSiteStatePushCommand
(XSiteState[] chunk) Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.buildXSiteStatePushRequest
(XSiteState[] chunk, long timeoutMillis) buildXSiteStateTransferControlRequest
(boolean startReceiving) buildXSiteStateTransferFinishSendCommand
(String siteName, boolean statusOk) buildXSiteStateTransferRestartSendingCommand
(String siteName, int topologyId) buildXSiteStateTransferStartSendCommand
(String siteName, int topologyId) buildXSiteTakeOfflineCommand
(String siteName) Retrieves the cache name this CommandFactory is set up to construct commands for.void
initializeReplicableCommand
(ReplicableCommand c, boolean isRemote) Initializes aReplicableCommand
read from a data stream with components specific to the target cache instance.void
start()
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.infinispan.commands.CommandsFactory
buildPutKeyValueCommand, buildRemoveCommand, buildReplaceCommand, buildSingleRpcCommand
-
Constructor Details
-
CommandsFactoryImpl
public CommandsFactoryImpl()
-
-
Method Details
-
start
public void start() -
buildPutKeyValueCommand
public org.infinispan.commands.write.PutKeyValueCommand buildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) - Specified by:
buildPutKeyValueCommand
in interfaceCommandsFactory
-
buildRemoveCommand
public org.infinispan.commands.write.RemoveCommand buildRemoveCommand(Object key, Object value, int segment, long flagsBitSet, boolean returnEntry) - Specified by:
buildRemoveCommand
in interfaceCommandsFactory
-
buildInvalidateCommand
public org.infinispan.commands.write.InvalidateCommand buildInvalidateCommand(long flagsBitSet, Object... keys) Description copied from interface:CommandsFactory
Builds an InvalidateCommand- Specified by:
buildInvalidateCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cachekeys
- keys to invalidate- Returns:
- an InvalidateCommand
-
buildInvalidateFromL1Command
public org.infinispan.commands.write.InvalidateCommand buildInvalidateFromL1Command(long flagsBitSet, Collection<Object> keys) Description copied from interface:CommandsFactory
Builds an InvalidateFromL1Command- Specified by:
buildInvalidateFromL1Command
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cachekeys
- keys to invalidate- Returns:
- an InvalidateFromL1Command
-
buildInvalidateFromL1Command
public org.infinispan.commands.write.InvalidateCommand buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys) - Specified by:
buildInvalidateFromL1Command
in interfaceCommandsFactory
- See Also:
-
buildRemoveExpiredCommand
public org.infinispan.commands.write.RemoveExpiredCommand buildRemoveExpiredCommand(Object key, Object value, int segment, Long lifespan, long flagsBitSet) Description copied from interface:CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via lifespan- Specified by:
buildRemoveExpiredCommand
in interfaceCommandsFactory
- 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
public org.infinispan.commands.write.RemoveExpiredCommand buildRemoveExpiredCommand(Object key, Object value, int segment, long flagsBitSet) Description copied from interface:CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via maxIdle- Specified by:
buildRemoveExpiredCommand
in interfaceCommandsFactory
- 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
public org.infinispan.commands.write.ReplaceCommand buildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) Description copied from interface:CommandsFactory
Builds a ReplaceCommand- Specified by:
buildReplaceCommand
in interfaceCommandsFactory
- 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 cachereturnEntry
- true if theCacheEntry
is the command response, otherwise returns previous value.- Returns:
- a ReplaceCommand
-
buildComputeCommand
public org.infinispan.commands.write.ComputeCommand buildComputeCommand(Object key, BiFunction mappingFunction, boolean computeIfPresent, int segment, Metadata metadata, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a ComputeCommand- Specified by:
buildComputeCommand
in interfaceCommandsFactory
- 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
public org.infinispan.commands.write.ComputeIfAbsentCommand buildComputeIfAbsentCommand(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a ComputeIfAbsentCommand- Specified by:
buildComputeIfAbsentCommand
in interfaceCommandsFactory
- 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
Description copied from interface:CommandsFactory
Builds a SizeCommand- Specified by:
buildSizeCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a SizeCommand
-
buildKeySetCommand
public org.infinispan.commands.read.KeySetCommand buildKeySetCommand(long flagsBitSet) Description copied from interface:CommandsFactory
Builds a KeySetCommand- Specified by:
buildKeySetCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a KeySetCommand
-
buildEntrySetCommand
public org.infinispan.commands.read.EntrySetCommand buildEntrySetCommand(long flagsBitSet) Description copied from interface:CommandsFactory
Builds a EntrySetCommand- Specified by:
buildEntrySetCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a EntrySetCommand
-
buildGetKeyValueCommand
public org.infinispan.commands.read.GetKeyValueCommand buildGetKeyValueCommand(Object key, int segment, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a GetKeyValueCommand- Specified by:
buildGetKeyValueCommand
in interfaceCommandsFactory
- Parameters:
key
- key to getsegment
- the segment of the given keyflagsBitSet
- Command flags provided by cache- Returns:
- a GetKeyValueCommand
-
buildGetAllCommand
public org.infinispan.commands.read.GetAllCommand buildGetAllCommand(Collection<?> keys, long flagsBitSet, boolean returnEntries) Description copied from interface:CommandsFactory
Builds a GetAllCommand- Specified by:
buildGetAllCommand
in interfaceCommandsFactory
- 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
-
buildPutMapCommand
public org.infinispan.commands.write.PutMapCommand buildPutMapCommand(Map<?, ?> map, Metadata metadata, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a PutMapCommand- Specified by:
buildPutMapCommand
in interfaceCommandsFactory
- Parameters:
map
- map containing key/value entries to putmetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a PutMapCommand
-
buildClearCommand
public org.infinispan.commands.write.ClearCommand buildClearCommand(long flagsBitSet) Description copied from interface:CommandsFactory
Builds a ClearCommand- Specified by:
buildClearCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a ClearCommand
-
buildEvictCommand
public org.infinispan.commands.write.EvictCommand buildEvictCommand(Object key, int segment, long flagsBitSet) Description copied from interface:CommandsFactory
Builds an EvictCommand- Specified by:
buildEvictCommand
in interfaceCommandsFactory
- Parameters:
key
- key to evictsegment
- the segment for the keyflagsBitSet
- Command flags provided by cache- Returns:
- an EvictCommand
-
buildPrepareCommand
public org.infinispan.commands.tx.PrepareCommand buildPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhaseCommit) Description copied from interface:CommandsFactory
Builds a PrepareCommand- Specified by:
buildPrepareCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the preparemodifications
- list of modificationsonePhaseCommit
- is this a one-phase or two-phase transaction?- Returns:
- a PrepareCommand
-
buildVersionedPrepareCommand
public org.infinispan.commands.tx.VersionedPrepareCommand buildVersionedPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhase) Description copied from interface:CommandsFactory
Builds a VersionedPrepareCommand- Specified by:
buildVersionedPrepareCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the preparemodifications
- list of modificationsonePhase
-- Returns:
- a VersionedPrepareCommand
-
buildCommitCommand
Description copied from interface:CommandsFactory
Builds a CommitCommand- Specified by:
buildCommitCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the commit- Returns:
- a CommitCommand
-
buildVersionedCommitCommand
public org.infinispan.commands.tx.VersionedCommitCommand buildVersionedCommitCommand(GlobalTransaction gtx) Description copied from interface:CommandsFactory
Builds a VersionedCommitCommand- Specified by:
buildVersionedCommitCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the commit- Returns:
- a VersionedCommitCommand
-
buildRollbackCommand
Description copied from interface:CommandsFactory
Builds a RollbackCommand- Specified by:
buildRollbackCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the rollback- Returns:
- a RollbackCommand
-
buildSingleRpcCommand
Description copied from interface:CommandsFactory
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand- Specified by:
buildSingleRpcCommand
in interfaceCommandsFactory
- Parameters:
call
- VisitableCommand to include in the envelope- Returns:
- a SingleRpcCommand
-
buildClusteredGetCommand
public org.infinispan.commands.remote.ClusteredGetCommand buildClusteredGetCommand(Object key, Integer segment, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command- Specified by:
buildClusteredGetCommand
in interfaceCommandsFactory
- 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
-
initializeReplicableCommand
Description copied from interface:CommandsFactory
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.- Specified by:
initializeReplicableCommand
in interfaceCommandsFactory
- Parameters:
c
- command to initialize. Cannot be null.isRemote
- true if the command is deserialized and is executed remote.
-
buildLockControlCommand
public org.infinispan.commands.control.LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx) Description copied from interface:CommandsFactory
Builds a LockControlCommand to control explicit remote locking- Specified by:
buildLockControlCommand
in interfaceCommandsFactory
- Parameters:
keys
- keys to lockflagsBitSet
- Command flags provided by cachegtx
-- Returns:
- a LockControlCommand
-
buildLockControlCommand
public org.infinispan.commands.control.LockControlCommand buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx) Description copied from interface:CommandsFactory
Same asCommandsFactory.buildLockControlCommand(Collection, long, GlobalTransaction)
but for locking a single key vs a collection of keys.- Specified by:
buildLockControlCommand
in interfaceCommandsFactory
-
buildLockControlCommand
public org.infinispan.commands.control.LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet) - Specified by:
buildLockControlCommand
in interfaceCommandsFactory
-
buildConflictResolutionStartCommand
public org.infinispan.commands.statetransfer.ConflictResolutionStartCommand buildConflictResolutionStartCommand(int topologyId, IntSet segments) - Specified by:
buildConflictResolutionStartCommand
in interfaceCommandsFactory
-
buildScatteredStateConfirmRevokeCommand
public org.infinispan.commands.statetransfer.ScatteredStateConfirmRevokedCommand buildScatteredStateConfirmRevokeCommand(int topologyId, IntSet segments) - Specified by:
buildScatteredStateConfirmRevokeCommand
in interfaceCommandsFactory
-
buildScatteredStateGetKeysCommand
public org.infinispan.commands.statetransfer.ScatteredStateGetKeysCommand buildScatteredStateGetKeysCommand(int topologyId, IntSet segments) - Specified by:
buildScatteredStateGetKeysCommand
in interfaceCommandsFactory
-
buildStateTransferCancelCommand
public org.infinispan.commands.statetransfer.StateTransferCancelCommand buildStateTransferCancelCommand(int topologyId, IntSet segments) - Specified by:
buildStateTransferCancelCommand
in interfaceCommandsFactory
-
buildStateTransferGetListenersCommand
public org.infinispan.commands.statetransfer.StateTransferGetListenersCommand buildStateTransferGetListenersCommand(int topologyId) - Specified by:
buildStateTransferGetListenersCommand
in interfaceCommandsFactory
-
buildStateTransferGetTransactionsCommand
public org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommand buildStateTransferGetTransactionsCommand(int topologyId, IntSet segments) - Specified by:
buildStateTransferGetTransactionsCommand
in interfaceCommandsFactory
-
buildStateTransferStartCommand
public org.infinispan.commands.statetransfer.StateTransferStartCommand buildStateTransferStartCommand(int topologyId, IntSet segments) - Specified by:
buildStateTransferStartCommand
in interfaceCommandsFactory
-
buildStateResponseCommand
public org.infinispan.commands.statetransfer.StateResponseCommand buildStateResponseCommand(int topologyId, Collection<org.infinispan.statetransfer.StateChunk> stateChunks, boolean applyState, boolean pushTransfer) Description copied from interface:CommandsFactory
Builds a StateResponseCommand used for pushing cache entries to another node.- Specified by:
buildStateResponseCommand
in interfaceCommandsFactory
-
getCacheName
Description copied from interface:CommandsFactory
Retrieves the cache name this CommandFactory is set up to construct commands for.- Specified by:
getCacheName
in interfaceCommandsFactory
- Returns:
- the name of the cache this CommandFactory is set up to construct commands for.
-
buildGetInDoubtTransactionsCommand
public org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand buildGetInDoubtTransactionsCommand()Description copied from interface:CommandsFactory
Builds aGetInDoubtTransactionsCommand
.- Specified by:
buildGetInDoubtTransactionsCommand
in interfaceCommandsFactory
-
buildTxCompletionNotificationCommand
public org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand buildTxCompletionNotificationCommand(XidImpl xid, GlobalTransaction globalTransaction) Description copied from interface:CommandsFactory
Builds aTxCompletionNotificationCommand
.- Specified by:
buildTxCompletionNotificationCommand
in interfaceCommandsFactory
-
buildTxCompletionNotificationCommand
public org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand buildTxCompletionNotificationCommand(long internalId) - Specified by:
buildTxCompletionNotificationCommand
in interfaceCommandsFactory
- Parameters:
internalId
- the internal id identifying the transaction to be removed.- See Also:
-
buildGetInDoubtTxInfoCommand
public org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand buildGetInDoubtTxInfoCommand()- Specified by:
buildGetInDoubtTxInfoCommand
in interfaceCommandsFactory
- See Also:
-
buildCompleteTransactionCommand
public org.infinispan.commands.remote.recovery.CompleteTransactionCommand buildCompleteTransactionCommand(XidImpl xid, boolean commit) Description copied from interface:CommandsFactory
Builds a CompleteTransactionCommand command.- Specified by:
buildCompleteTransactionCommand
in interfaceCommandsFactory
- Parameters:
xid
- the xid identifying the transaction we want to complete.commit
- commit(true) or rollback(false)?
-
buildXSiteStateTransferCancelSendCommand
public XSiteStateTransferCancelSendCommand buildXSiteStateTransferCancelSendCommand(String siteName) - Specified by:
buildXSiteStateTransferCancelSendCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferClearStatusCommand
- Specified by:
buildXSiteStateTransferClearStatusCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferFinishReceiveCommand
public XSiteStateTransferFinishReceiveCommand buildXSiteStateTransferFinishReceiveCommand(String siteName) - Specified by:
buildXSiteStateTransferFinishReceiveCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferFinishSendCommand
public XSiteStateTransferFinishSendCommand buildXSiteStateTransferFinishSendCommand(String siteName, boolean statusOk) - Specified by:
buildXSiteStateTransferFinishSendCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferRestartSendingCommand
public XSiteStateTransferRestartSendingCommand buildXSiteStateTransferRestartSendingCommand(String siteName, int topologyId) - Specified by:
buildXSiteStateTransferRestartSendingCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferStartReceiveCommand
public XSiteStateTransferStartReceiveCommand buildXSiteStateTransferStartReceiveCommand(String siteName) - Specified by:
buildXSiteStateTransferStartReceiveCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferStartSendCommand
public XSiteStateTransferStartSendCommand buildXSiteStateTransferStartSendCommand(String siteName, int topologyId) - Specified by:
buildXSiteStateTransferStartSendCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferStatusRequestCommand
- Specified by:
buildXSiteStateTransferStatusRequestCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferControlRequest
public XSiteStateTransferControlRequest buildXSiteStateTransferControlRequest(boolean startReceiving) - Specified by:
buildXSiteStateTransferControlRequest
in interfaceCommandsFactory
-
buildXSiteAmendOfflineStatusCommand
public XSiteAmendOfflineStatusCommand buildXSiteAmendOfflineStatusCommand(String siteName, Integer afterFailures, Long minTimeToWait) - Specified by:
buildXSiteAmendOfflineStatusCommand
in interfaceCommandsFactory
-
buildXSiteBringOnlineCommand
- Specified by:
buildXSiteBringOnlineCommand
in interfaceCommandsFactory
-
buildXSiteOfflineStatusCommand
- Specified by:
buildXSiteOfflineStatusCommand
in interfaceCommandsFactory
-
buildXSiteStatusCommand
- Specified by:
buildXSiteStatusCommand
in interfaceCommandsFactory
-
buildXSiteTakeOfflineCommand
- Specified by:
buildXSiteTakeOfflineCommand
in interfaceCommandsFactory
-
buildXSiteStatePushCommand
Description copied from interface:CommandsFactory
Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.- Specified by:
buildXSiteStatePushCommand
in interfaceCommandsFactory
- Parameters:
chunk
- the data chunk- Returns:
- the XSiteStatePushCommand created
-
buildSingleXSiteRpcCommand
public org.infinispan.xsite.SingleXSiteRpcCommand buildSingleXSiteRpcCommand(VisitableCommand command) Description copied from interface:CommandsFactory
Builds SingleRpcCommand used to performVisitableCommand
on the backup site,- Specified by:
buildSingleXSiteRpcCommand
in interfaceCommandsFactory
- Parameters:
command
- the visitable command.- Returns:
- the SingleXSiteRpcCommand created
-
buildGetCacheEntryCommand
public org.infinispan.commands.read.GetCacheEntryCommand buildGetCacheEntryCommand(Object key, int segment, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a GetCacheEntryCommand- Specified by:
buildGetCacheEntryCommand
in interfaceCommandsFactory
- Parameters:
key
- key to getsegment
- the segment for the keyflagsBitSet
- Command flags provided by cache- Returns:
- a GetCacheEntryCommand
-
buildClusteredGetAllCommand
public org.infinispan.commands.remote.ClusteredGetAllCommand buildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx) Description copied from interface:CommandsFactory
Builds a ClusteredGetAllCommand, which is a remote lookup command- Specified by:
buildClusteredGetAllCommand
in interfaceCommandsFactory
- Parameters:
keys
- key to look upflagsBitSet
- Command flags provided by cache- Returns:
- a ClusteredGetAllCommand
-
buildReadOnlyKeyCommand
public <K,V, org.infinispan.commands.functional.ReadOnlyKeyCommand<K,R> V, buildReadOnlyKeyCommandR> (Object key, Function<EntryView.ReadEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadOnlyKeyCommand
in interfaceCommandsFactory
-
buildReadOnlyManyCommand
public <K,V, org.infinispan.commands.functional.ReadOnlyManyCommand<K,R> V, buildReadOnlyManyCommandR> (Collection<?> keys, Function<EntryView.ReadEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadOnlyManyCommand
in interfaceCommandsFactory
-
buildReadWriteKeyValueCommand
public <K,V, org.infinispan.commands.functional.ReadWriteKeyValueCommand<K,T, R> V, buildReadWriteKeyValueCommandT, R> (Object key, Object argument, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteKeyValueCommand
in interfaceCommandsFactory
-
buildReadWriteKeyCommand
public <K,V, org.infinispan.commands.functional.ReadWriteKeyCommand<K,R> V, buildReadWriteKeyCommandR> (Object key, Function<EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteKeyCommand
in interfaceCommandsFactory
-
buildReadWriteManyCommand
public <K,V, org.infinispan.commands.functional.ReadWriteManyCommand<K,R> V, buildReadWriteManyCommandR> (Collection<?> keys, Function<EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteManyCommand
in interfaceCommandsFactory
-
buildReadWriteManyEntriesCommand
public <K,V, org.infinispan.commands.functional.ReadWriteManyEntriesCommand<K,T, R> V, buildReadWriteManyEntriesCommandT, R> (Map<?, ?> entries, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteManyEntriesCommand
in interfaceCommandsFactory
-
buildInvalidateVersionsCommand
public org.infinispan.commands.write.InvalidateVersionsCommand buildInvalidateVersionsCommand(int topologyId, Object[] keys, int[] topologyIds, long[] versions, boolean removed) - Specified by:
buildInvalidateVersionsCommand
in interfaceCommandsFactory
-
buildWriteOnlyKeyCommand
public <K,V> org.infinispan.commands.functional.WriteOnlyKeyCommand<K,V> buildWriteOnlyKeyCommand(Object key, Consumer<EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyKeyCommand
in interfaceCommandsFactory
-
buildWriteOnlyKeyValueCommand
public <K,V, org.infinispan.commands.functional.WriteOnlyKeyValueCommand<K,T> V, buildWriteOnlyKeyValueCommandT> (Object key, Object argument, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyKeyValueCommand
in interfaceCommandsFactory
-
buildWriteOnlyManyCommand
public <K,V> org.infinispan.commands.functional.WriteOnlyManyCommand<K,V> buildWriteOnlyManyCommand(Collection<?> keys, Consumer<EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyManyCommand
in interfaceCommandsFactory
-
buildWriteOnlyManyEntriesCommand
public <K,V, org.infinispan.commands.functional.WriteOnlyManyEntriesCommand<K,T> V, buildWriteOnlyManyEntriesCommandT> (Map<?, ?> arguments, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyManyEntriesCommand
in interfaceCommandsFactory
-
buildTxReadOnlyKeyCommand
public <K,V, org.infinispan.commands.functional.TxReadOnlyKeyCommand<K,R> V, buildTxReadOnlyKeyCommandR> (Object key, Function<EntryView.ReadEntryView<K, V>, R> f, List<org.infinispan.commands.functional.Mutation<K, V, ?>> mutations, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildTxReadOnlyKeyCommand
in interfaceCommandsFactory
-
buildTxReadOnlyManyCommand
public <K,V, org.infinispan.commands.functional.TxReadOnlyManyCommand<K,R> V, buildTxReadOnlyManyCommandR> (Collection<?> keys, List<List<org.infinispan.commands.functional.Mutation<K, V, ?>>> mutations, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildTxReadOnlyManyCommand
in interfaceCommandsFactory
-
buildBackupAckCommand
public org.infinispan.commands.write.BackupAckCommand buildBackupAckCommand(long id, int topologyId) - Specified by:
buildBackupAckCommand
in interfaceCommandsFactory
-
buildBackupMultiKeyAckCommand
public org.infinispan.commands.write.BackupMultiKeyAckCommand buildBackupMultiKeyAckCommand(long id, int segment, int topologyId) - Specified by:
buildBackupMultiKeyAckCommand
in interfaceCommandsFactory
-
buildExceptionAckCommand
public org.infinispan.commands.write.ExceptionAckCommand buildExceptionAckCommand(long id, Throwable throwable, int topologyId) - Specified by:
buildExceptionAckCommand
in interfaceCommandsFactory
-
buildRevokeBiasCommand
public org.infinispan.commands.remote.RevokeBiasCommand buildRevokeBiasCommand(Address ackTarget, long id, int topologyId, Collection<Object> keys) - Specified by:
buildRevokeBiasCommand
in interfaceCommandsFactory
-
buildRenewBiasCommand
- Specified by:
buildRenewBiasCommand
in interfaceCommandsFactory
-
buildSingleKeyBackupWriteCommand
public org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand()- Specified by:
buildSingleKeyBackupWriteCommand
in interfaceCommandsFactory
-
buildSingleKeyFunctionalBackupWriteCommand
public org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyFunctionalBackupWriteCommand()- Specified by:
buildSingleKeyFunctionalBackupWriteCommand
in interfaceCommandsFactory
-
buildPutMapBackupWriteCommand
public org.infinispan.commands.triangle.PutMapBackupWriteCommand buildPutMapBackupWriteCommand()- Specified by:
buildPutMapBackupWriteCommand
in interfaceCommandsFactory
-
buildMultiEntriesFunctionalBackupWriteCommand
public org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand buildMultiEntriesFunctionalBackupWriteCommand()- Specified by:
buildMultiEntriesFunctionalBackupWriteCommand
in interfaceCommandsFactory
-
buildMultiKeyFunctionalBackupWriteCommand
public org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand buildMultiKeyFunctionalBackupWriteCommand()- Specified by:
buildMultiKeyFunctionalBackupWriteCommand
in interfaceCommandsFactory
-
buildBackupNoopCommand
public org.infinispan.commands.triangle.BackupNoopCommand buildBackupNoopCommand()- Specified by:
buildBackupNoopCommand
in interfaceCommandsFactory
-
buildKeyReductionPublisherCommand
public <K,R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand<K> buildKeyReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) - Specified by:
buildKeyReductionPublisherCommand
in interfaceCommandsFactory
-
buildEntryReductionPublisherCommand
public <K,V, org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand<K> buildEntryReductionPublisherCommandR> (boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) - Specified by:
buildEntryReductionPublisherCommand
in interfaceCommandsFactory
-
buildInitialPublisherCommand
public <K,I, org.infinispan.reactive.publisher.impl.commands.batch.InitialPublisherCommand<K,R> I, buildInitialPublisherCommandR> (String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>, ? extends org.reactivestreams.Publisher<R>> transformer) - Specified by:
buildInitialPublisherCommand
in interfaceCommandsFactory
-
buildNextPublisherCommand
public org.infinispan.reactive.publisher.impl.commands.batch.NextPublisherCommand buildNextPublisherCommand(String requestId) - Specified by:
buildNextPublisherCommand
in interfaceCommandsFactory
-
buildCancelPublisherCommand
public org.infinispan.reactive.publisher.impl.commands.batch.CancelPublisherCommand buildCancelPublisherCommand(String requestId) - Specified by:
buildCancelPublisherCommand
in interfaceCommandsFactory
-
buildMultiClusterEventCommand
public <K,V> MultiClusterEventCommand<K,V> buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>> events) - Specified by:
buildMultiClusterEventCommand
in interfaceCommandsFactory
-
buildCheckTransactionRpcCommand
public org.infinispan.commands.remote.CheckTransactionRpcCommand buildCheckTransactionRpcCommand(Collection<GlobalTransaction> globalTransactions) - Specified by:
buildCheckTransactionRpcCommand
in interfaceCommandsFactory
-
buildTouchCommand
public TouchCommand buildTouchCommand(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet) - Specified by:
buildTouchCommand
in interfaceCommandsFactory
-
buildIracClearKeysCommand
- Specified by:
buildIracClearKeysCommand
in interfaceCommandsFactory
-
buildIracCleanupKeyCommand
public org.infinispan.commands.irac.IracCleanupKeysCommand buildIracCleanupKeyCommand(Collection<? extends IracManagerKeyInfo> state) - Specified by:
buildIracCleanupKeyCommand
in interfaceCommandsFactory
-
buildIracTombstoneCleanupCommand
public org.infinispan.commands.irac.IracTombstoneCleanupCommand buildIracTombstoneCleanupCommand(int maxCapacity) - Specified by:
buildIracTombstoneCleanupCommand
in interfaceCommandsFactory
-
buildIracMetadataRequestCommand
public org.infinispan.commands.irac.IracMetadataRequestCommand buildIracMetadataRequestCommand(int segment, IracEntryVersion versionSeen) - Specified by:
buildIracMetadataRequestCommand
in interfaceCommandsFactory
-
buildIracRequestStateCommand
public org.infinispan.commands.irac.IracRequestStateCommand buildIracRequestStateCommand(IntSet segments) - Specified by:
buildIracRequestStateCommand
in interfaceCommandsFactory
-
buildIracStateResponseCommand
public org.infinispan.commands.irac.IracStateResponseCommand buildIracStateResponseCommand(int capacity) - Specified by:
buildIracStateResponseCommand
in interfaceCommandsFactory
-
buildIracPutKeyValueCommand
public org.infinispan.commands.write.IracPutKeyValueCommand buildIracPutKeyValueCommand(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata) - Specified by:
buildIracPutKeyValueCommand
in interfaceCommandsFactory
-
buildIracTouchCommand
- Specified by:
buildIracTouchCommand
in interfaceCommandsFactory
-
buildIracUpdateVersionCommand
public org.infinispan.commands.irac.IracUpdateVersionCommand buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion> segmentsVersion) - Specified by:
buildIracUpdateVersionCommand
in interfaceCommandsFactory
-
buildXSiteAutoTransferStatusCommand
- Specified by:
buildXSiteAutoTransferStatusCommand
in interfaceCommandsFactory
-
buildXSiteSetStateTransferModeCommand
public XSiteSetStateTransferModeCommand buildXSiteSetStateTransferModeCommand(String site, XSiteStateTransferMode mode) - Specified by:
buildXSiteSetStateTransferModeCommand
in interfaceCommandsFactory
-
buildIracTombstoneRemoteSiteCheckCommand
public org.infinispan.commands.irac.IracTombstoneRemoteSiteCheckCommand buildIracTombstoneRemoteSiteCheckCommand(List<Object> keys) - Specified by:
buildIracTombstoneRemoteSiteCheckCommand
in interfaceCommandsFactory
-
buildIracTombstoneStateResponseCommand
public org.infinispan.commands.irac.IracTombstoneStateResponseCommand buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo> state) - Specified by:
buildIracTombstoneStateResponseCommand
in interfaceCommandsFactory
-
buildIracTombstonePrimaryCheckCommand
public org.infinispan.commands.irac.IracTombstonePrimaryCheckCommand buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo> tombstones) - Specified by:
buildIracTombstonePrimaryCheckCommand
in interfaceCommandsFactory
-
buildIracPutManyCommand
- Specified by:
buildIracPutManyCommand
in interfaceCommandsFactory
-
buildXSiteStatePushRequest
- Specified by:
buildXSiteStatePushRequest
in interfaceCommandsFactory
-
buildIracTombstoneCheckRequest
- Specified by:
buildIracTombstoneCheckRequest
in interfaceCommandsFactory
-