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.
Since:
4.0
Author:
Manik Surtani, Mircea.Markus@jboss.com, Galder Zamarreño
  • Method Details

    • buildPutKeyValueCommand

      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

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

      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

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

      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

      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

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

      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

      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

      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

      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

      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

      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

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

      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

      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

      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

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

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

      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

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

      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

      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

      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

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

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

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

      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

      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

      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

      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

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

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

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

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

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

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

      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

      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

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

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

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

      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

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

      XSiteStateTransferCancelSendCommand buildXSiteStateTransferCancelSendCommand(String siteName)
    • buildXSiteStateTransferClearStatusCommand

      XSiteStateTransferClearStatusCommand buildXSiteStateTransferClearStatusCommand()
    • buildXSiteStateTransferFinishReceiveCommand

      XSiteStateTransferFinishReceiveCommand buildXSiteStateTransferFinishReceiveCommand(String siteName)
    • buildXSiteStateTransferFinishSendCommand

      XSiteStateTransferFinishSendCommand buildXSiteStateTransferFinishSendCommand(String siteName, boolean statusOk)
    • buildXSiteStateTransferRestartSendingCommand

      XSiteStateTransferRestartSendingCommand buildXSiteStateTransferRestartSendingCommand(String siteName, int topologyId)
    • buildXSiteStateTransferStartReceiveCommand

      XSiteStateTransferStartReceiveCommand buildXSiteStateTransferStartReceiveCommand(String siteName)
    • buildXSiteStateTransferStartSendCommand

      XSiteStateTransferStartSendCommand buildXSiteStateTransferStartSendCommand(String siteName, int topologyId)
    • buildXSiteStateTransferStatusRequestCommand

      XSiteStateTransferStatusRequestCommand buildXSiteStateTransferStatusRequestCommand()
    • buildXSiteStateTransferControlRequest

      XSiteStateTransferControlRequest buildXSiteStateTransferControlRequest(boolean startReceiving)
    • buildXSiteAmendOfflineStatusCommand

      XSiteAmendOfflineStatusCommand buildXSiteAmendOfflineStatusCommand(String siteName, Integer afterFailures, Long minTimeToWait)
    • buildXSiteStatePushCommand

      @Deprecated(since="16.0", forRemoval=true) default XSiteStatePushCommand buildXSiteStatePushCommand(XSiteState[] chunk)
      Deprecated, for removal: This API element is subject to removal in a future version.
      since 16.0, use buildXSiteStatePushCommand(List) instead
      Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.
      Parameters:
      chunk - the data chunk
      Returns:
      the XSiteStatePushCommand created
    • buildXSiteStatePushCommand

      XSiteStatePushCommand buildXSiteStatePushCommand(List<XSiteState> chunk)
      Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.
      Parameters:
      chunk - the data chunk
      Returns:
      the XSiteStatePushCommand created
    • buildSingleXSiteRpcCommand

      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

      <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

      <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

      <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,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

      <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

      <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

      <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

      <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,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

      <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

      <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

      <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

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

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

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.write.ReplaceCommand command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.write.ComputeIfAbsentCommand command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.write.ComputeCommand command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.write.PutKeyValueCommand command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.write.IracPutKeyValueCommand command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      org.infinispan.commands.triangle.SingleKeyBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.write.RemoveCommand command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      <K,V,T,R> org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.functional.ReadWriteKeyValueCommand<K,V,T,R> command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      <K,V,R> org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.functional.ReadWriteKeyCommand<K,V,R> command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      <K,V> org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.functional.WriteOnlyKeyCommand<K,V> command, long sequence, int segmentId)
    • buildSingleKeyBackupWriteCommand

      <K,V,T> org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand buildSingleKeyBackupWriteCommand(org.infinispan.commands.functional.WriteOnlyKeyValueCommand<K,V,T> command, long sequence, int segmentId)
    • buildPutMapBackupWriteCommand

      org.infinispan.commands.triangle.PutMapBackupWriteCommand buildPutMapBackupWriteCommand(org.infinispan.commands.write.PutMapCommand command, Collection<Object> keys, long sequence, int segmentId)
    • buildMultiEntriesFunctionalBackupWriteCommand

      <K,V,T> org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand buildMultiEntriesFunctionalBackupWriteCommand(org.infinispan.commands.functional.WriteOnlyManyEntriesCommand<K,V,T> command, Collection<Object> keys, long sequence, int segmentId)
    • buildMultiEntriesFunctionalBackupWriteCommand

      <K,V,T,R> org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand buildMultiEntriesFunctionalBackupWriteCommand(org.infinispan.commands.functional.ReadWriteManyEntriesCommand<K,V,T,R> command, Collection<Object> keys, long sequence, int segmentId)
    • buildMultiKeyFunctionalBackupWriteCommand

      <K,V> org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand buildMultiKeyFunctionalBackupWriteCommand(org.infinispan.commands.functional.WriteOnlyManyCommand<K,V> command, Collection<Object> keys, long sequence, int segmentId)
    • buildMultiKeyFunctionalBackupWriteCommand

      <K,V,R> org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand buildMultiKeyFunctionalBackupWriteCommand(org.infinispan.commands.functional.ReadWriteManyCommand<K,V,R> command, Collection<Object> keys, long sequence, int segmentId)
    • buildBackupNoopCommand

      org.infinispan.commands.triangle.BackupNoopCommand buildBackupNoopCommand(org.infinispan.commands.write.WriteCommand command, long sequence, int segmentId)
    • 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,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

      <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

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

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

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

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

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

      IracClearKeysRequest buildIracClearKeysCommand()
    • buildIracCleanupKeyCommand

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

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

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

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

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

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

      IracTouchKeyRequest buildIracTouchCommand(Object key)
    • buildIracUpdateVersionCommand

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

      XSiteAutoTransferStatusCommand buildXSiteAutoTransferStatusCommand(String site)
    • buildXSiteSetStateTransferModeCommand

      XSiteSetStateTransferModeCommand buildXSiteSetStateTransferModeCommand(String site, XSiteStateTransferMode mode)
    • buildIracTombstoneRemoteSiteCheckCommand

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

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

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

      IracPutManyRequest buildIracPutManyCommand(int capacity)
    • buildXSiteStatePushRequest

      @Deprecated(since="16.0", forRemoval=true) default XSiteStatePushRequest buildXSiteStatePushRequest(XSiteState[] chunk, long timeoutMillis)
      Deprecated, for removal: This API element is subject to removal in a future version.
    • buildXSiteStatePushRequest

      XSiteStatePushRequest buildXSiteStatePushRequest(List<XSiteState> chunk, long timeoutMillis)
    • buildIracTombstoneCheckRequest

      IracTombstoneCheckRequest buildIracTombstoneCheckRequest(List<Object> keys)
    • buildIracPrimaryPendingKeyCheckCommand

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