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 via initializeReplicableCommand(ReplicableCommand, boolean) before being invoked.
 
 Note, InitializableCommand implementations should not rely on access to the ComponentRegistry in their constructors for local execution initialization as this leads to
 duplicated code. Instead implementations of this interface should call InitializableCommand.init(ComponentRegistry, boolean) before returning the created command.
- Since:
- 4.0
- Author:
- Manik Surtani, Mircea.Markus@jboss.com, Galder Zamarreño
- 
Method SummaryModifier and TypeMethodDescriptionorg.infinispan.commands.write.BackupMultiKeyAckCommandbuildBackupMultiKeyAckCommand(long id, int segment, int topologyId) org.infinispan.commands.triangle.BackupNoopCommandorg.infinispan.reactive.publisher.impl.commands.batch.CancelPublisherCommandbuildCancelPublisherCommand(String requestId) org.infinispan.commands.remote.CheckTransactionRpcCommandbuildCheckTransactionRpcCommand(Collection<GlobalTransaction> globalTransactions) org.infinispan.commands.write.ClearCommandbuildClearCommand(long flagsBitSet) Builds a ClearCommandorg.infinispan.commands.remote.ClusteredGetAllCommandbuildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a ClusteredGetAllCommand, which is a remote lookup commandorg.infinispan.commands.remote.ClusteredGetCommandbuildClusteredGetCommand(Object key, Integer segment, long flagsBitSet) Builds a ClusteredGetCommand, which is a remote lookup commandorg.infinispan.commands.tx.CommitCommandBuilds a CommitCommandorg.infinispan.commands.remote.recovery.CompleteTransactionCommandbuildCompleteTransactionCommand(XidImpl xid, boolean commit) Builds a CompleteTransactionCommand command.org.infinispan.commands.write.ComputeCommandbuildComputeCommand(Object key, BiFunction mappingFunction, boolean computeIfPresent, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeCommandorg.infinispan.commands.write.ComputeIfAbsentCommandbuildComputeIfAbsentCommand(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeIfAbsentCommandorg.infinispan.commands.statetransfer.ConflictResolutionStartCommandbuildConflictResolutionStartCommand(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.EntrySetCommandbuildEntrySetCommand(long flagsBitSet) Builds a EntrySetCommandorg.infinispan.commands.write.EvictCommandbuildEvictCommand(Object key, int segment, long flagsBitSet) Builds an EvictCommandorg.infinispan.commands.write.ExceptionAckCommandbuildExceptionAckCommand(long id, Throwable throwable, int topologyId) org.infinispan.commands.read.GetAllCommandbuildGetAllCommand(Collection<?> keys, long flagsBitSet, boolean returnEntries) Builds a GetAllCommandorg.infinispan.commands.read.GetCacheEntryCommandbuildGetCacheEntryCommand(Object key, int segment, long flagsBitSet) Builds a GetCacheEntryCommandorg.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommandBuilds aGetInDoubtTransactionsCommand.org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommandorg.infinispan.commands.read.GetKeyValueCommandbuildGetKeyValueCommand(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.InvalidateCommandbuildInvalidateCommand(long flagsBitSet, Object... keys) Builds an InvalidateCommandorg.infinispan.commands.write.InvalidateCommandbuildInvalidateFromL1Command(long flagsBitSet, Collection<Object> keys) Builds an InvalidateFromL1Commandorg.infinispan.commands.write.InvalidateCommandbuildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys) org.infinispan.commands.irac.IracCleanupKeysCommandorg.infinispan.commands.irac.IracMetadataRequestCommandbuildIracMetadataRequestCommand(int segment, IracEntryVersion versionSeen) org.infinispan.commands.write.IracPutKeyValueCommandbuildIracPutKeyValueCommand(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata) buildIracPutManyCommand(int capacity) org.infinispan.commands.irac.IracRequestStateCommandbuildIracRequestStateCommand(IntSet segments) org.infinispan.commands.irac.IracStateResponseCommandbuildIracStateResponseCommand(int capacity) org.infinispan.commands.irac.IracTombstoneCleanupCommandbuildIracTombstoneCleanupCommand(int maxCapacity) org.infinispan.commands.irac.IracTombstonePrimaryCheckCommandorg.infinispan.commands.irac.IracTombstoneRemoteSiteCheckCommandorg.infinispan.commands.irac.IracTombstoneStateResponseCommandorg.infinispan.commands.irac.IracUpdateVersionCommandbuildIracUpdateVersionCommand(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.KeySetCommandbuildKeySetCommand(long flagsBitSet) Builds a KeySetCommandorg.infinispan.commands.control.LockControlCommandbuildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx) Same asbuildLockControlCommand(Collection, long, GlobalTransaction)but for locking a single key vs a collection of keys.org.infinispan.commands.control.LockControlCommandbuildLockControlCommand(Collection<?> keys, long flagsBitSet) org.infinispan.commands.control.LockControlCommandbuildLockControlCommand(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.MultiEntriesFunctionalBackupWriteCommandorg.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommandorg.infinispan.reactive.publisher.impl.commands.batch.NextPublisherCommandbuildNextPublisherCommand(String requestId) org.infinispan.commands.tx.PrepareCommandbuildPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhaseCommit) Builds a PrepareCommanddefault org.infinispan.commands.write.PutKeyValueCommandbuildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet) Builds a PutKeyValueCommandorg.infinispan.commands.write.PutKeyValueCommandbuildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) org.infinispan.commands.triangle.PutMapBackupWriteCommandorg.infinispan.commands.write.PutMapCommandbuildPutMapCommand(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) default org.infinispan.commands.write.RemoveCommandbuildRemoveCommand(Object key, Object value, int segment, long flagsBitSet) Builds a RemoveCommandorg.infinispan.commands.write.RemoveCommandbuildRemoveCommand(Object key, Object value, int segment, long flagsBitSet, boolean returnEntry) org.infinispan.commands.write.RemoveExpiredCommandbuildRemoveExpiredCommand(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.RemoveExpiredCommandbuildRemoveExpiredCommand(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 lifespandefault org.infinispan.commands.write.ReplaceCommandbuildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet) Builds a ReplaceCommandorg.infinispan.commands.write.ReplaceCommandbuildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) Builds a ReplaceCommandorg.infinispan.commands.tx.RollbackCommandBuilds a RollbackCommandorg.infinispan.commands.triangle.SingleKeyBackupWriteCommandorg.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommanddefault org.infinispan.commands.remote.SingleRpcCommandDeprecated, for removal: This API element is subject to removal in a future version.org.infinispan.commands.remote.SingleRpcCommandbuildSingleRpcCommand(VisitableCommand command) Builds a SingleRpcCommand "envelope" containing a single ReplicableCommandorg.infinispan.xsite.SingleXSiteRpcCommandBuilds SingleRpcCommand used to performVisitableCommandon the backup site,org.infinispan.commands.read.SizeCommandbuildSizeCommand(IntSet segments, long flagsBitSet) Builds a SizeCommandorg.infinispan.commands.statetransfer.StateResponseCommandbuildStateResponseCommand(int viewId, Collection<org.infinispan.statetransfer.StateChunk> stateChunks, boolean applyState) Builds a StateResponseCommand used for pushing cache entries to another node.org.infinispan.commands.statetransfer.StateTransferCancelCommandbuildStateTransferCancelCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferGetListenersCommandbuildStateTransferGetListenersCommand(int topologyId) org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommandbuildStateTransferGetTransactionsCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferStartCommandbuildStateTransferStartCommand(int topologyId, IntSet segments) buildTouchCommand(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet) org.infinispan.commands.remote.recovery.TxCompletionNotificationCommandbuildTxCompletionNotificationCommand(long internalId) org.infinispan.commands.remote.recovery.TxCompletionNotificationCommandbuildTxCompletionNotificationCommand(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.VersionedCommitCommandBuilds a VersionedCommitCommandorg.infinispan.commands.tx.VersionedPrepareCommandbuildVersionedPrepareCommand(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.voidinitializeReplicableCommand(ReplicableCommand command, boolean isRemote) Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, please useCacheRpcCommand.invokeAsync(ComponentRegistry)orGlobalRpcCommand.invokeAsync(GlobalComponentRegistry)instead.
- 
Method Details- 
buildPutKeyValueCommanddefault org.infinispan.commands.write.PutKeyValueCommand buildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet) Builds a PutKeyValueCommand- Parameters:
- key- key to put
- value- value to put
- segment- the segment of the given key
- metadata- metadata of entry
- flagsBitSet- Command flags provided by cache
- Returns:
- a PutKeyValueCommand
 
- 
buildPutKeyValueCommand
- 
buildRemoveCommanddefault org.infinispan.commands.write.RemoveCommand buildRemoveCommand(Object key, Object value, int segment, long flagsBitSet) Builds a RemoveCommand- Parameters:
- key- key to remove
- value- value to check for ina conditional remove, or null for an unconditional remove.
- segment- the segment of the given key
- flagsBitSet- Command flags provided by cache
- Returns:
- a RemoveCommand
 
- 
buildRemoveCommand
- 
buildInvalidateCommandorg.infinispan.commands.write.InvalidateCommand buildInvalidateCommand(long flagsBitSet, Object... keys) Builds an InvalidateCommand- Parameters:
- flagsBitSet- Command flags provided by cache
- keys- keys to invalidate
- Returns:
- an InvalidateCommand
 
- 
buildInvalidateFromL1Commandorg.infinispan.commands.write.InvalidateCommand buildInvalidateFromL1Command(long flagsBitSet, Collection<Object> keys) Builds an InvalidateFromL1Command- Parameters:
- flagsBitSet- Command flags provided by cache
- keys- keys to invalidate
- Returns:
- an InvalidateFromL1Command
 
- 
buildInvalidateFromL1Commandorg.infinispan.commands.write.InvalidateCommand buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys) - See Also:
 
- 
buildRemoveExpiredCommandorg.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 lifespan- Parameters:
- key- the key of the expired entry
- value- the value of the entry when it was expired
- segment- the segment of the given key
- lifespan- the lifespan that expired from the command
- flagsBitSet- Command flags provided by cache
- Returns:
- a RemovedExpiredCommand
 
- 
buildRemoveExpiredCommandorg.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 maxIdle- Parameters:
- key- the key of the expired entry
- value- the value of the entry when it was expired
- segment- the segment of the given key
- flagsBitSet- Command flags provided by cache
- Returns:
- a RemovedExpiredCommand
 
- 
buildReplaceCommanddefault org.infinispan.commands.write.ReplaceCommand buildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet) Builds a ReplaceCommand- Parameters:
- key- key to replace
- oldValue- existing value to check for if conditional, null if unconditional.
- newValue- value to replace with
- segment- the segment of the given key
- metadata- metadata of entry
- flagsBitSet- Command flags provided by cache
- Returns:
- a ReplaceCommand
 
- 
buildReplaceCommandorg.infinispan.commands.write.ReplaceCommand buildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) Builds a ReplaceCommand- Parameters:
- key- key to replace
- oldValue- existing value to check for if conditional, null if unconditional.
- newValue- value to replace with
- segment- the segment of the given key
- metadata- metadata of entry
- flagsBitSet- Command flags provided by cache
- returnEntry- true if the- CacheEntryis the command response, otherwise returns previous value.
- Returns:
- a ReplaceCommand
 
- 
buildComputeCommandorg.infinispan.commands.write.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 absent
- mappingFunction- BiFunction for the key and the value
- computeIfPresent- flag to apply as computeIfPresent mode
- segment- the segment of the given key
- metadata- metadata of entry
- flagsBitSet- Command flags provided by cache
- Returns:
- a ComputeCommand
 
- 
buildComputeIfAbsentCommandorg.infinispan.commands.write.ComputeIfAbsentCommand buildComputeIfAbsentCommand(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeIfAbsentCommand- Parameters:
- key- key to compute if this key is absent
- mappingFunction- mappingFunction for the key
- segment- the segment of the given key
- metadata- metadata of entry
- flagsBitSet- Command flags provided by cache
- Returns:
- a ComputeCommand
 
- 
buildSizeCommandBuilds a SizeCommand- Parameters:
- flagsBitSet- Command flags provided by cache
- Returns:
- a SizeCommand
 
- 
buildGetKeyValueCommandorg.infinispan.commands.read.GetKeyValueCommand buildGetKeyValueCommand(Object key, int segment, long flagsBitSet) Builds a GetKeyValueCommand- Parameters:
- key- key to get
- segment- the segment of the given key
- flagsBitSet- Command flags provided by cache
- Returns:
- a GetKeyValueCommand
 
- 
buildGetCacheEntryCommandorg.infinispan.commands.read.GetCacheEntryCommand buildGetCacheEntryCommand(Object key, int segment, long flagsBitSet) Builds a GetCacheEntryCommand- Parameters:
- key- key to get
- segment- the segment for the key
- flagsBitSet- Command flags provided by cache
- Returns:
- a GetCacheEntryCommand
 
- 
buildGetAllCommandorg.infinispan.commands.read.GetAllCommand buildGetAllCommand(Collection<?> keys, long flagsBitSet, boolean returnEntries) Builds a GetAllCommand- Parameters:
- keys- keys to get
- flagsBitSet- Command flags provided by cache
- returnEntries- boolean indicating whether entire cache entries are returned, otherwise return just the value parts
- Returns:
- a GetKeyValueCommand
 
- 
buildKeySetCommandorg.infinispan.commands.read.KeySetCommand buildKeySetCommand(long flagsBitSet) Builds a KeySetCommand- Parameters:
- flagsBitSet- Command flags provided by cache
- Returns:
- a KeySetCommand
 
- 
buildEntrySetCommandorg.infinispan.commands.read.EntrySetCommand buildEntrySetCommand(long flagsBitSet) Builds a EntrySetCommand- Parameters:
- flagsBitSet- Command flags provided by cache
- Returns:
- a EntrySetCommand
 
- 
buildPutMapCommandorg.infinispan.commands.write.PutMapCommand buildPutMapCommand(Map<?, ?> map, Metadata metadata, long flagsBitSet) Builds a PutMapCommand- Parameters:
- map- map containing key/value entries to put
- metadata- metadata of entry
- flagsBitSet- Command flags provided by cache
- Returns:
- a PutMapCommand
 
- 
buildClearCommandorg.infinispan.commands.write.ClearCommand buildClearCommand(long flagsBitSet) Builds a ClearCommand- Parameters:
- flagsBitSet- Command flags provided by cache
- Returns:
- a ClearCommand
 
- 
buildEvictCommandorg.infinispan.commands.write.EvictCommand buildEvictCommand(Object key, int segment, long flagsBitSet) Builds an EvictCommand- Parameters:
- key- key to evict
- segment- the segment for the key
- flagsBitSet- Command flags provided by cache
- Returns:
- an EvictCommand
 
- 
buildPrepareCommandorg.infinispan.commands.tx.PrepareCommand buildPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhaseCommit) Builds a PrepareCommand- Parameters:
- gtx- global transaction associated with the prepare
- modifications- list of modifications
- onePhaseCommit- is this a one-phase or two-phase transaction?
- Returns:
- a PrepareCommand
 
- 
buildVersionedPrepareCommandorg.infinispan.commands.tx.VersionedPrepareCommand buildVersionedPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhase) Builds a VersionedPrepareCommand- Parameters:
- gtx- global transaction associated with the prepare
- modifications- list of modifications
- onePhase-
- Returns:
- a VersionedPrepareCommand
 
- 
buildCommitCommandBuilds a CommitCommand- Parameters:
- gtx- global transaction associated with the commit
- Returns:
- a CommitCommand
 
- 
buildVersionedCommitCommandorg.infinispan.commands.tx.VersionedCommitCommand buildVersionedCommitCommand(GlobalTransaction gtx) Builds a VersionedCommitCommand- Parameters:
- gtx- global transaction associated with the commit
- Returns:
- a VersionedCommitCommand
 
- 
buildRollbackCommandBuilds a RollbackCommand- Parameters:
- gtx- global transaction associated with the rollback
- Returns:
- a RollbackCommand
 
- 
initializeReplicableCommand@Deprecated(forRemoval=true, since="11.0") void initializeReplicableCommand(ReplicableCommand command, boolean isRemote) Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, please useCacheRpcCommand.invokeAsync(ComponentRegistry)orGlobalRpcCommand.invokeAsync(GlobalComponentRegistry)instead. to access any components required at invocation time.Initializes aReplicableCommandread 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(forRemoval=true, since="11.0") default org.infinispan.commands.remote.SingleRpcCommand buildSingleRpcCommand(ReplicableCommand call) Deprecated, for removal: This API element is subject to removal in a future version.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
 
- 
buildSingleRpcCommandBuilds a SingleRpcCommand "envelope" containing a single ReplicableCommand- Parameters:
- command- VisitableCommand to include in the envelope
- Returns:
- a SingleRpcCommand
 
- 
buildClusteredGetCommandorg.infinispan.commands.remote.ClusteredGetCommand buildClusteredGetCommand(Object key, Integer segment, long flagsBitSet) Builds a ClusteredGetCommand, which is a remote lookup command- Parameters:
- key- key to look up
- segment- the segment for the key or null if it should be computed on the remote node
- flagsBitSet- Command flags provided by cache
- Returns:
- a ClusteredGetCommand
 
- 
buildClusteredGetAllCommandorg.infinispan.commands.remote.ClusteredGetAllCommand buildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a ClusteredGetAllCommand, which is a remote lookup command- Parameters:
- keys- key to look up
- flagsBitSet- Command flags provided by cache
- Returns:
- a ClusteredGetAllCommand
 
- 
buildLockControlCommandorg.infinispan.commands.control.LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a LockControlCommand to control explicit remote locking- Parameters:
- keys- keys to lock
- flagsBitSet- Command flags provided by cache
- gtx-
- Returns:
- a LockControlCommand
 
- 
buildLockControlCommandorg.infinispan.commands.control.LockControlCommand buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx) Same asbuildLockControlCommand(Collection, long, GlobalTransaction)but for locking a single key vs a collection of keys.
- 
buildLockControlCommandorg.infinispan.commands.control.LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet) 
- 
buildConflictResolutionStartCommandorg.infinispan.commands.statetransfer.ConflictResolutionStartCommand buildConflictResolutionStartCommand(int topologyId, IntSet segments) 
- 
buildStateTransferCancelCommandorg.infinispan.commands.statetransfer.StateTransferCancelCommand buildStateTransferCancelCommand(int topologyId, IntSet segments) 
- 
buildStateTransferGetListenersCommandorg.infinispan.commands.statetransfer.StateTransferGetListenersCommand buildStateTransferGetListenersCommand(int topologyId) 
- 
buildStateTransferGetTransactionsCommandorg.infinispan.commands.statetransfer.StateTransferGetTransactionsCommand buildStateTransferGetTransactionsCommand(int topologyId, IntSet segments) 
- 
buildStateTransferStartCommandorg.infinispan.commands.statetransfer.StateTransferStartCommand buildStateTransferStartCommand(int topologyId, IntSet segments) 
- 
buildStateResponseCommandorg.infinispan.commands.statetransfer.StateResponseCommand buildStateResponseCommand(int viewId, Collection<org.infinispan.statetransfer.StateChunk> stateChunks, boolean applyState) Builds a StateResponseCommand used for pushing cache entries to another node.
- 
getCacheNameString 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.
 
- 
buildGetInDoubtTransactionsCommandorg.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand buildGetInDoubtTransactionsCommand()Builds aGetInDoubtTransactionsCommand.
- 
buildTxCompletionNotificationCommandorg.infinispan.commands.remote.recovery.TxCompletionNotificationCommand buildTxCompletionNotificationCommand(XidImpl xid, GlobalTransaction globalTransaction) Builds aTxCompletionNotificationCommand.
- 
buildGetInDoubtTxInfoCommandorg.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand buildGetInDoubtTxInfoCommand()- See Also:
 
- 
buildCompleteTransactionCommandorg.infinispan.commands.remote.recovery.CompleteTransactionCommand buildCompleteTransactionCommand(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)?
 
- 
buildTxCompletionNotificationCommandorg.infinispan.commands.remote.recovery.TxCompletionNotificationCommand buildTxCompletionNotificationCommand(long internalId) - Parameters:
- internalId- the internal id identifying the transaction to be removed.
- See Also:
 
- 
buildXSiteStateTransferCancelSendCommand
- 
buildXSiteStateTransferClearStatusCommandXSiteStateTransferClearStatusCommand buildXSiteStateTransferClearStatusCommand()
- 
buildXSiteStateTransferFinishReceiveCommand
- 
buildXSiteStateTransferFinishSendCommandXSiteStateTransferFinishSendCommand buildXSiteStateTransferFinishSendCommand(String siteName, boolean statusOk) 
- 
buildXSiteStateTransferRestartSendingCommandXSiteStateTransferRestartSendingCommand buildXSiteStateTransferRestartSendingCommand(String siteName, int topologyId) 
- 
buildXSiteStateTransferStartReceiveCommand
- 
buildXSiteStateTransferStartSendCommandXSiteStateTransferStartSendCommand buildXSiteStateTransferStartSendCommand(String siteName, int topologyId) 
- 
buildXSiteStateTransferStatusRequestCommandXSiteStateTransferStatusRequestCommand buildXSiteStateTransferStatusRequestCommand()
- 
buildXSiteStateTransferControlRequest
- 
buildXSiteAmendOfflineStatusCommandXSiteAmendOfflineStatusCommand buildXSiteAmendOfflineStatusCommand(String siteName, Integer afterFailures, Long minTimeToWait) 
- 
buildXSiteBringOnlineCommand
- 
buildXSiteOfflineStatusCommand
- 
buildXSiteStatusCommandXSiteStatusCommand buildXSiteStatusCommand()
- 
buildXSiteTakeOfflineCommand
- 
buildXSiteStatePushCommandBuilds XSiteStatePushCommand used to transfer a single chunk of data between sites.- Parameters:
- chunk- the data chunk
- Returns:
- the XSiteStatePushCommand created
 
- 
buildSingleXSiteRpcCommandBuilds SingleRpcCommand used to performVisitableCommandon the backup site,- Parameters:
- command- the visitable command.
- Returns:
- the SingleXSiteRpcCommand created
 
- 
buildReadOnlyKeyCommand<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) 
- 
buildReadOnlyManyCommand<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) 
- 
buildWriteOnlyKeyCommand<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) 
- 
buildReadWriteKeyValueCommand<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) 
- 
buildReadWriteKeyCommand<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) 
- 
buildWriteOnlyManyEntriesCommand<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) 
- 
buildWriteOnlyKeyValueCommand<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) 
- 
buildWriteOnlyManyCommand<K,V> org.infinispan.commands.functional.WriteOnlyManyCommand<K,V> buildWriteOnlyManyCommand(Collection<?> keys, Consumer<EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) 
- 
buildReadWriteManyCommand<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) 
- 
buildReadWriteManyEntriesCommand<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) 
- 
buildTxReadOnlyKeyCommand<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) 
- 
buildTxReadOnlyManyCommand<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) 
- 
buildBackupMultiKeyAckCommandorg.infinispan.commands.write.BackupMultiKeyAckCommand buildBackupMultiKeyAckCommand(long id, int segment, int topologyId) 
- 
buildExceptionAckCommandorg.infinispan.commands.write.ExceptionAckCommand buildExceptionAckCommand(long id, Throwable throwable, int topologyId) 
- 
buildSingleKeyBackupWriteCommandorg.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand()
- 
buildSingleKeyFunctionalBackupWriteCommandorg.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyFunctionalBackupWriteCommand()
- 
buildPutMapBackupWriteCommandorg.infinispan.commands.triangle.PutMapBackupWriteCommand buildPutMapBackupWriteCommand()
- 
buildMultiEntriesFunctionalBackupWriteCommandorg.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand buildMultiEntriesFunctionalBackupWriteCommand()
- 
buildMultiKeyFunctionalBackupWriteCommandorg.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand buildMultiKeyFunctionalBackupWriteCommand()
- 
buildBackupNoopCommandorg.infinispan.commands.triangle.BackupNoopCommand buildBackupNoopCommand()
- 
buildKeyReductionPublisherCommand<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) 
- 
buildEntryReductionPublisherCommand<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) 
- 
buildInitialPublisherCommand<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) 
- 
buildNextPublisherCommandorg.infinispan.reactive.publisher.impl.commands.batch.NextPublisherCommand buildNextPublisherCommand(String requestId) 
- 
buildCancelPublisherCommandorg.infinispan.reactive.publisher.impl.commands.batch.CancelPublisherCommand buildCancelPublisherCommand(String requestId) 
- 
buildMultiClusterEventCommand<K,V> MultiClusterEventCommand<K,V> buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>> events) 
- 
buildCheckTransactionRpcCommandorg.infinispan.commands.remote.CheckTransactionRpcCommand buildCheckTransactionRpcCommand(Collection<GlobalTransaction> globalTransactions) 
- 
buildTouchCommandTouchCommand buildTouchCommand(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet) 
- 
buildIracClearKeysCommandIracClearKeysRequest buildIracClearKeysCommand()
- 
buildIracCleanupKeyCommandorg.infinispan.commands.irac.IracCleanupKeysCommand buildIracCleanupKeyCommand(Collection<IracManagerKeyInfo> state) 
- 
buildIracTombstoneCleanupCommandorg.infinispan.commands.irac.IracTombstoneCleanupCommand buildIracTombstoneCleanupCommand(int maxCapacity) 
- 
buildIracMetadataRequestCommandorg.infinispan.commands.irac.IracMetadataRequestCommand buildIracMetadataRequestCommand(int segment, IracEntryVersion versionSeen) 
- 
buildIracRequestStateCommand
- 
buildIracStateResponseCommandorg.infinispan.commands.irac.IracStateResponseCommand buildIracStateResponseCommand(int capacity) 
- 
buildIracPutKeyValueCommandorg.infinispan.commands.write.IracPutKeyValueCommand buildIracPutKeyValueCommand(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata) 
- 
buildIracTouchCommand
- 
buildIracUpdateVersionCommandorg.infinispan.commands.irac.IracUpdateVersionCommand buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion> segmentsVersion) 
- 
buildXSiteAutoTransferStatusCommand
- 
buildXSiteSetStateTransferModeCommandXSiteSetStateTransferModeCommand buildXSiteSetStateTransferModeCommand(String site, XSiteStateTransferMode mode) 
- 
buildIracTombstoneRemoteSiteCheckCommand
- 
buildIracTombstoneStateResponseCommandorg.infinispan.commands.irac.IracTombstoneStateResponseCommand buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo> state) 
- 
buildIracTombstonePrimaryCheckCommandorg.infinispan.commands.irac.IracTombstonePrimaryCheckCommand buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo> tombstones) 
- 
buildIracPutManyCommand
- 
buildXSiteStatePushRequest
- 
buildIracTombstoneCheckRequest
 
- 
buildSingleRpcCommand(VisitableCommand)instead.