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 Details Link icon

    • buildPutKeyValueCommand Link icon

      default 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 Link icon

      org.infinispan.commands.write.PutKeyValueCommand buildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry)
    • buildRemoveCommand Link icon

      default 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 Link icon

      org.infinispan.commands.write.RemoveCommand buildRemoveCommand(Object key, Object value, int segment, long flagsBitSet, boolean returnEntry)
    • buildInvalidateCommand Link icon

      org.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
    • buildInvalidateFromL1Command Link icon

      org.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
    • buildInvalidateFromL1Command Link icon

      org.infinispan.commands.write.InvalidateCommand buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys)
      See Also:
    • buildRemoveExpiredCommand Link icon

      org.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
    • buildRemoveExpiredCommand Link icon

      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 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
    • buildReplaceCommand Link icon

      default 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
    • buildReplaceCommand Link icon

      org.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 CacheEntry is the command response, otherwise returns previous value.
      Returns:
      a ReplaceCommand
    • buildComputeCommand Link icon

      org.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
    • buildComputeIfAbsentCommand Link icon

      org.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
    • buildSizeCommand Link icon

      org.infinispan.commands.read.SizeCommand buildSizeCommand(IntSet segments, long flagsBitSet)
      Builds a SizeCommand
      Parameters:
      flagsBitSet - Command flags provided by cache
      Returns:
      a SizeCommand
    • buildGetKeyValueCommand Link icon

      org.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
    • buildGetCacheEntryCommand Link icon

      org.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
    • buildGetAllCommand Link icon

      org.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
    • buildKeySetCommand Link icon

      org.infinispan.commands.read.KeySetCommand buildKeySetCommand(long flagsBitSet)
      Builds a KeySetCommand
      Parameters:
      flagsBitSet - Command flags provided by cache
      Returns:
      a KeySetCommand
    • buildEntrySetCommand Link icon

      org.infinispan.commands.read.EntrySetCommand buildEntrySetCommand(long flagsBitSet)
      Builds a EntrySetCommand
      Parameters:
      flagsBitSet - Command flags provided by cache
      Returns:
      a EntrySetCommand
    • buildPutMapCommand Link icon

      org.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
    • buildClearCommand Link icon

      org.infinispan.commands.write.ClearCommand buildClearCommand(long flagsBitSet)
      Builds a ClearCommand
      Parameters:
      flagsBitSet - Command flags provided by cache
      Returns:
      a ClearCommand
    • buildEvictCommand Link icon

      org.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
    • buildPrepareCommand Link icon

      org.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
    • buildVersionedPrepareCommand Link icon

      org.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
    • buildCommitCommand Link icon

      org.infinispan.commands.tx.CommitCommand buildCommitCommand(GlobalTransaction gtx)
      Builds a CommitCommand
      Parameters:
      gtx - global transaction associated with the commit
      Returns:
      a CommitCommand
    • buildVersionedCommitCommand Link icon

      org.infinispan.commands.tx.VersionedCommitCommand buildVersionedCommitCommand(GlobalTransaction gtx)
      Builds a VersionedCommitCommand
      Parameters:
      gtx - global transaction associated with the commit
      Returns:
      a VersionedCommitCommand
    • buildRollbackCommand Link icon

      org.infinispan.commands.tx.RollbackCommand buildRollbackCommand(GlobalTransaction gtx)
      Builds a RollbackCommand
      Parameters:
      gtx - global transaction associated with the rollback
      Returns:
      a RollbackCommand
    • initializeReplicableCommand Link icon

      @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 use CacheRpcCommand.invokeAsync(ComponentRegistry) or GlobalRpcCommand.invokeAsync(GlobalComponentRegistry) instead. to access any components required at invocation time.
      Initializes a ReplicableCommand 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 Link icon

      @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.
      Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
      Parameters:
      call - ReplicableCommand to include in the envelope
      Returns:
      a SingleRpcCommand
    • buildSingleRpcCommand Link icon

      org.infinispan.commands.remote.SingleRpcCommand buildSingleRpcCommand(VisitableCommand command)
      Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
      Parameters:
      command - VisitableCommand to include in the envelope
      Returns:
      a SingleRpcCommand
    • buildClusteredGetCommand Link icon

      org.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
    • buildClusteredGetAllCommand Link icon

      org.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
    • buildLockControlCommand Link icon

      org.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
    • buildLockControlCommand Link icon

      org.infinispan.commands.control.LockControlCommand buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx)
      Same as buildLockControlCommand(Collection, long, GlobalTransaction) but for locking a single key vs a collection of keys.
    • buildLockControlCommand Link icon

      org.infinispan.commands.control.LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet)
    • buildConflictResolutionStartCommand Link icon

      org.infinispan.commands.statetransfer.ConflictResolutionStartCommand buildConflictResolutionStartCommand(int topologyId, IntSet segments)
    • buildStateTransferCancelCommand Link icon

      org.infinispan.commands.statetransfer.StateTransferCancelCommand buildStateTransferCancelCommand(int topologyId, IntSet segments)
    • buildStateTransferGetListenersCommand Link icon

      org.infinispan.commands.statetransfer.StateTransferGetListenersCommand buildStateTransferGetListenersCommand(int topologyId)
    • buildStateTransferGetTransactionsCommand Link icon

      org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommand buildStateTransferGetTransactionsCommand(int topologyId, IntSet segments)
    • buildStateTransferStartCommand Link icon

      org.infinispan.commands.statetransfer.StateTransferStartCommand buildStateTransferStartCommand(int topologyId, IntSet segments)
    • buildStateResponseCommand Link icon

      org.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.
    • getCacheName Link icon

      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 Link icon

      org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand buildGetInDoubtTransactionsCommand()
      Builds a GetInDoubtTransactionsCommand.
    • buildTxCompletionNotificationCommand Link icon

      org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand buildTxCompletionNotificationCommand(XidImpl xid, GlobalTransaction globalTransaction)
      Builds a TxCompletionNotificationCommand.
    • buildGetInDoubtTxInfoCommand Link icon

      org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand buildGetInDoubtTxInfoCommand()
      See Also:
      • GetInDoubtTxInfoCommand
    • buildCompleteTransactionCommand Link icon

      org.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)?
    • buildTxCompletionNotificationCommand Link icon

      org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand buildTxCompletionNotificationCommand(long internalId)
      Parameters:
      internalId - the internal id identifying the transaction to be removed.
      See Also:
      • TxCompletionNotificationCommand
    • buildXSiteStateTransferCancelSendCommand Link icon

      XSiteStateTransferCancelSendCommand buildXSiteStateTransferCancelSendCommand(String siteName)
    • buildXSiteStateTransferClearStatusCommand Link icon

      XSiteStateTransferClearStatusCommand buildXSiteStateTransferClearStatusCommand()
    • buildXSiteStateTransferFinishReceiveCommand Link icon

      XSiteStateTransferFinishReceiveCommand buildXSiteStateTransferFinishReceiveCommand(String siteName)
    • buildXSiteStateTransferFinishSendCommand Link icon

      XSiteStateTransferFinishSendCommand buildXSiteStateTransferFinishSendCommand(String siteName, boolean statusOk)
    • buildXSiteStateTransferRestartSendingCommand Link icon

      XSiteStateTransferRestartSendingCommand buildXSiteStateTransferRestartSendingCommand(String siteName, int topologyId)
    • buildXSiteStateTransferStartReceiveCommand Link icon

      XSiteStateTransferStartReceiveCommand buildXSiteStateTransferStartReceiveCommand(String siteName)
    • buildXSiteStateTransferStartSendCommand Link icon

      XSiteStateTransferStartSendCommand buildXSiteStateTransferStartSendCommand(String siteName, int topologyId)
    • buildXSiteStateTransferStatusRequestCommand Link icon

      XSiteStateTransferStatusRequestCommand buildXSiteStateTransferStatusRequestCommand()
    • buildXSiteStateTransferControlRequest Link icon

      XSiteStateTransferControlRequest buildXSiteStateTransferControlRequest(boolean startReceiving)
    • buildXSiteAmendOfflineStatusCommand Link icon

      XSiteAmendOfflineStatusCommand buildXSiteAmendOfflineStatusCommand(String siteName, Integer afterFailures, Long minTimeToWait)
    • buildXSiteBringOnlineCommand Link icon

      @Deprecated(since="15.1", forRemoval=true) default XSiteBringOnlineCommand buildXSiteBringOnlineCommand(String siteName)
      Deprecated, for removal: This API element is subject to removal in a future version.
    • buildXSiteOfflineStatusCommand Link icon

      @Deprecated(since="15.1", forRemoval=true) default XSiteOfflineStatusCommand buildXSiteOfflineStatusCommand(String siteName)
      Deprecated, for removal: This API element is subject to removal in a future version.
    • buildXSiteStatusCommand Link icon

      @Deprecated(since="15.1", forRemoval=true) default XSiteStatusCommand buildXSiteStatusCommand()
      Deprecated, for removal: This API element is subject to removal in a future version.
    • buildXSiteTakeOfflineCommand Link icon

      @Deprecated(since="15.1", forRemoval=true) default XSiteTakeOfflineCommand buildXSiteTakeOfflineCommand(String siteName)
      Deprecated, for removal: This API element is subject to removal in a future version.
    • buildXSiteStatePushCommand Link icon

      XSiteStatePushCommand buildXSiteStatePushCommand(XSiteState[] chunk)
      Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.
      Parameters:
      chunk - the data chunk
      Returns:
      the XSiteStatePushCommand created
    • buildSingleXSiteRpcCommand Link icon

      org.infinispan.xsite.SingleXSiteRpcCommand buildSingleXSiteRpcCommand(VisitableCommand command)
      Builds SingleRpcCommand used to perform VisitableCommand on the backup site,
      Parameters:
      command - the visitable command.
      Returns:
      the SingleXSiteRpcCommand created
    • buildReadOnlyKeyCommand Link icon

      <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)
    • buildReadOnlyManyCommand Link icon

      <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)
    • buildWriteOnlyKeyCommand Link icon

      <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 Link icon

      <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)
    • buildReadWriteKeyCommand Link icon

      <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)
    • buildWriteOnlyManyEntriesCommand Link icon

      <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)
    • buildWriteOnlyKeyValueCommand Link icon

      <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)
    • buildWriteOnlyManyCommand Link icon

      <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 Link icon

      <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)
    • buildReadWriteManyEntriesCommand Link icon

      <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)
    • buildTxReadOnlyKeyCommand Link icon

      <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)
    • buildTxReadOnlyManyCommand Link icon

      <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)
    • buildBackupMultiKeyAckCommand Link icon

      org.infinispan.commands.write.BackupMultiKeyAckCommand buildBackupMultiKeyAckCommand(long id, int segment, int topologyId)
    • buildExceptionAckCommand Link icon

      org.infinispan.commands.write.ExceptionAckCommand buildExceptionAckCommand(long id, Throwable throwable, int topologyId)
    • buildSingleKeyBackupWriteCommand Link icon

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand()
    • buildSingleKeyFunctionalBackupWriteCommand Link icon

      org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyFunctionalBackupWriteCommand()
    • buildPutMapBackupWriteCommand Link icon

      org.infinispan.commands.triangle.PutMapBackupWriteCommand buildPutMapBackupWriteCommand()
    • buildMultiEntriesFunctionalBackupWriteCommand Link icon

      org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand buildMultiEntriesFunctionalBackupWriteCommand()
    • buildMultiKeyFunctionalBackupWriteCommand Link icon

      org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand buildMultiKeyFunctionalBackupWriteCommand()
    • buildBackupNoopCommand Link icon

      org.infinispan.commands.triangle.BackupNoopCommand buildBackupNoopCommand()
    • buildKeyReductionPublisherCommand Link icon

      <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 Link icon

      <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)
    • buildInitialPublisherCommand Link icon

      <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)
    • buildNextPublisherCommand Link icon

      org.infinispan.reactive.publisher.impl.commands.batch.NextPublisherCommand buildNextPublisherCommand(String requestId)
    • buildCancelPublisherCommand Link icon

      org.infinispan.reactive.publisher.impl.commands.batch.CancelPublisherCommand buildCancelPublisherCommand(String requestId)
    • buildMultiClusterEventCommand Link icon

      <K,V> MultiClusterEventCommand<K,V> buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K,V>>> events)
    • buildCheckTransactionRpcCommand Link icon

      org.infinispan.commands.remote.CheckTransactionRpcCommand buildCheckTransactionRpcCommand(Collection<GlobalTransaction> globalTransactions)
    • buildTouchCommand Link icon

      TouchCommand buildTouchCommand(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet)
    • buildIracClearKeysCommand Link icon

      IracClearKeysRequest buildIracClearKeysCommand()
    • buildIracCleanupKeyCommand Link icon

      org.infinispan.commands.irac.IracCleanupKeysCommand buildIracCleanupKeyCommand(Collection<IracManagerKeyInfo> state)
    • buildIracTombstoneCleanupCommand Link icon

      org.infinispan.commands.irac.IracTombstoneCleanupCommand buildIracTombstoneCleanupCommand(int maxCapacity)
    • buildIracMetadataRequestCommand Link icon

      org.infinispan.commands.irac.IracMetadataRequestCommand buildIracMetadataRequestCommand(int segment, IracEntryVersion versionSeen)
    • buildIracRequestStateCommand Link icon

      org.infinispan.commands.irac.IracRequestStateCommand buildIracRequestStateCommand(IntSet segments)
    • buildIracStateResponseCommand Link icon

      org.infinispan.commands.irac.IracStateResponseCommand buildIracStateResponseCommand(int capacity)
    • buildIracPutKeyValueCommand Link icon

      org.infinispan.commands.write.IracPutKeyValueCommand buildIracPutKeyValueCommand(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata)
    • buildIracTouchCommand Link icon

      IracTouchKeyRequest buildIracTouchCommand(Object key)
    • buildIracUpdateVersionCommand Link icon

      org.infinispan.commands.irac.IracUpdateVersionCommand buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion> segmentsVersion)
    • buildXSiteAutoTransferStatusCommand Link icon

      XSiteAutoTransferStatusCommand buildXSiteAutoTransferStatusCommand(String site)
    • buildXSiteSetStateTransferModeCommand Link icon

      XSiteSetStateTransferModeCommand buildXSiteSetStateTransferModeCommand(String site, XSiteStateTransferMode mode)
    • buildIracTombstoneRemoteSiteCheckCommand Link icon

      org.infinispan.commands.irac.IracTombstoneRemoteSiteCheckCommand buildIracTombstoneRemoteSiteCheckCommand(List<Object> keys)
    • buildIracTombstoneStateResponseCommand Link icon

      org.infinispan.commands.irac.IracTombstoneStateResponseCommand buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo> state)
    • buildIracTombstonePrimaryCheckCommand Link icon

      org.infinispan.commands.irac.IracTombstonePrimaryCheckCommand buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo> tombstones)
    • buildIracPutManyCommand Link icon

      IracPutManyRequest buildIracPutManyCommand(int capacity)
    • buildXSiteStatePushRequest Link icon

      XSiteStatePushRequest buildXSiteStatePushRequest(XSiteState[] chunk, long timeoutMillis)
    • buildIracTombstoneCheckRequest Link icon

      IracTombstoneCheckRequest buildIracTombstoneCheckRequest(List<Object> keys)
    • buildIracPrimaryPendingKeyCheckCommand Link icon

      org.infinispan.commands.irac.IracPrimaryPendingKeyCheckCommand buildIracPrimaryPendingKeyCheckCommand(List<IracManagerKeyInfo> keys)