Package org.infinispan.commands
Class CommandsFactoryImpl
java.lang.Object
org.infinispan.commands.CommandsFactoryImpl
- All Implemented Interfaces:
CommandsFactory
- Since:
- 4.0
- Author:
- [email protected], Galder ZamarreƱo, Sanne Grinovero <[email protected]> (C) 2011 Red Hat Inc.
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionbuildBackupMultiKeyAckCommand
(long id, int segment, int topologyId) buildCancelPublisherCommand
(String requestId) buildCheckTransactionRpcCommand
(Collection<GlobalTransaction> globalTransactions) buildClearCommand
(long flagsBitSet) Builds a ClearCommandbuildClusteredGetAllCommand
(List<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a ClusteredGetAllCommand, which is a remote lookup commandbuildClusteredGetCommand
(Object key, Integer segment, long flagsBitSet) Builds a ClusteredGetCommand, which is a remote lookup commandBuilds a CommitCommandbuildCompleteTransactionCommand
(org.infinispan.commons.tx.XidImpl xid, boolean commit) Builds a CompleteTransactionCommand command.buildComputeCommand
(Object key, BiFunction mappingFunction, boolean computeIfPresent, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeCommandbuildComputeIfAbsentCommand
(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet) Builds a ComputeIfAbsentCommandbuildConflictResolutionStartCommand
(int topologyId, org.infinispan.commons.util.IntSet segments) <K,
V, R> ReductionPublisherRequestCommand <K> buildEntryReductionPublisherCommand
(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, org.infinispan.commons.util.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) buildEntrySetCommand
(long flagsBitSet) Builds a EntrySetCommandbuildEvictCommand
(Object key, int segment, long flagsBitSet) Builds an EvictCommandbuildExceptionAckCommand
(long id, Throwable throwable, int topologyId) buildGetAllCommand
(Collection<?> keys, long flagsBitSet, boolean returnEntries) Builds a GetAllCommandbuildGetCacheEntryCommand
(Object key, int segment, long flagsBitSet) Builds a GetCacheEntryCommandBuilds aGetInDoubtTransactionsCommand
.buildGetKeyValueCommand
(Object key, int segment, long flagsBitSet) Builds a GetKeyValueCommand<K,
I, R> InitialPublisherCommand <K, I, R> buildInitialPublisherCommand
(String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>, ? extends org.reactivestreams.Publisher<R>> transformer) buildInvalidateCommand
(long flagsBitSet, Object... keys) Builds an InvalidateCommandbuildInvalidateFromL1Command
(long flagsBitSet, Collection<Object> keys) Builds an InvalidateFromL1CommandbuildInvalidateFromL1Command
(Address origin, long flagsBitSet, Collection<Object> keys) buildIracMetadataRequestCommand
(int segment, IracEntryVersion versionSeen) buildIracPutKeyValueCommand
(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata) buildIracPutManyCommand
(int capacity) buildIracRequestStateCommand
(org.infinispan.commons.util.IntSet segments) buildIracStateResponseCommand
(int capacity) buildIracTombstoneCleanupCommand
(int maxCapacity) buildIracUpdateVersionCommand
(Map<Integer, IracEntryVersion> segmentsVersion) <K,
R> ReductionPublisherRequestCommand <K> buildKeyReductionPublisherCommand
(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, org.infinispan.commons.util.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) buildKeySetCommand
(long flagsBitSet) Builds a KeySetCommandbuildLockControlCommand
(Object key, long flagsBitSet, GlobalTransaction gtx) Same asCommandsFactory.buildLockControlCommand(Collection, long, GlobalTransaction)
but for locking a single key vs a collection of keys.buildLockControlCommand
(Collection<?> keys, long flagsBitSet) buildLockControlCommand
(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx) Builds a LockControlCommand to control explicit remote locking<K,
V> MultiClusterEventCommand <K, V> buildMultiClusterEventCommand
(Map<UUID, Collection<ClusterEvent<K, V>>> events) buildNextPublisherCommand
(String requestId) buildPrepareCommand
(GlobalTransaction gtx, List<WriteCommand> modifications, boolean onePhaseCommit) Builds a PrepareCommandbuildPutKeyValueCommand
(Object key, Object value, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) buildPutMapCommand
(Map<?, ?> map, Metadata metadata, long flagsBitSet) Builds a PutMapCommand<K,
V, R> ReadOnlyKeyCommand <K, V, R> buildReadOnlyKeyCommand
(Object key, Function<EntryView.ReadEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> ReadOnlyManyCommand <K, V, R> buildReadOnlyManyCommand
(Collection<?> keys, Function<EntryView.ReadEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> ReadWriteKeyCommand <K, V, R> buildReadWriteKeyCommand
(Object key, Function<EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T, R>
ReadWriteKeyValueCommand<K, V, T, R> buildReadWriteKeyValueCommand
(Object key, Object argument, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> ReadWriteManyCommand <K, V, R> buildReadWriteManyCommand
(Collection<?> keys, Function<EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T, R>
ReadWriteManyEntriesCommand<K, V, T, R> buildReadWriteManyEntriesCommand
(Map<?, ?> entries, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) buildRemoveCommand
(Object key, Object value, int segment, long flagsBitSet, boolean returnEntry) 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 maxIdlebuildRemoveExpiredCommand
(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 lifespanbuildReplaceCommand
(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) Builds a ReplaceCommandBuilds a RollbackCommandBuilds a SingleRpcCommand "envelope" containing a single ReplicableCommandBuilds SingleRpcCommand used to performVisitableCommand
on the backup site,buildSizeCommand
(org.infinispan.commons.util.IntSet segments, long flagsBitSet) Builds a SizeCommandbuildStateResponseCommand
(int topologyId, Collection<StateChunk> stateChunks, boolean applyState) Builds a StateResponseCommand used for pushing cache entries to another node.buildStateTransferCancelCommand
(int topologyId, org.infinispan.commons.util.IntSet segments) buildStateTransferGetListenersCommand
(int topologyId) buildStateTransferGetTransactionsCommand
(int topologyId, org.infinispan.commons.util.IntSet segments) buildStateTransferStartCommand
(int topologyId, org.infinispan.commons.util.IntSet segments) buildTouchCommand
(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet) buildTxCompletionNotificationCommand
(long internalId) buildTxCompletionNotificationCommand
(org.infinispan.commons.tx.XidImpl xid, GlobalTransaction globalTransaction) Builds aTxCompletionNotificationCommand
.<K,
V, R> TxReadOnlyKeyCommand <K, V, R> buildTxReadOnlyKeyCommand
(Object key, Function<EntryView.ReadEntryView<K, V>, R> f, List<Mutation<K, V, ?>> mutations, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, R> TxReadOnlyManyCommand <K, V, R> buildTxReadOnlyManyCommand
(Collection<?> keys, List<List<Mutation<K, V, ?>>> mutations, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) Builds a VersionedCommitCommandbuildVersionedPrepareCommand
(GlobalTransaction gtx, List<WriteCommand> modifications, boolean onePhase) Builds a VersionedPrepareCommand<K,
V> WriteOnlyKeyCommand <K, V> buildWriteOnlyKeyCommand
(Object key, Consumer<EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T> WriteOnlyKeyValueCommand <K, V, T> buildWriteOnlyKeyValueCommand
(Object key, Object argument, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V> WriteOnlyManyCommand <K, V> buildWriteOnlyManyCommand
(Collection<?> keys, Consumer<EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) <K,
V, T> WriteOnlyManyEntriesCommand <K, V, T> buildWriteOnlyManyEntriesCommand
(Map<?, ?> arguments, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) buildXSiteAmendOfflineStatusCommand
(String siteName, Integer afterFailures, Long minTimeToWait) buildXSiteBringOnlineCommand
(String siteName) buildXSiteOfflineStatusCommand
(String siteName) buildXSiteStatePushCommand
(XSiteState[] chunk) Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.buildXSiteStatePushRequest
(XSiteState[] chunk, long timeoutMillis) buildXSiteStateTransferControlRequest
(boolean startReceiving) buildXSiteStateTransferFinishSendCommand
(String siteName, boolean statusOk) buildXSiteStateTransferRestartSendingCommand
(String siteName, int topologyId) buildXSiteStateTransferStartSendCommand
(String siteName, int topologyId) buildXSiteTakeOfflineCommand
(String siteName) Retrieves the cache name this CommandFactory is set up to construct commands for.void
initializeReplicableCommand
(ReplicableCommand c, boolean isRemote) Initializes aReplicableCommand
read from a data stream with components specific to the target cache instance.void
start()
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.infinispan.commands.CommandsFactory
buildPutKeyValueCommand, buildRemoveCommand, buildReplaceCommand, buildSingleRpcCommand
-
Constructor Details
-
CommandsFactoryImpl
public CommandsFactoryImpl()
-
-
Method Details
-
start
public void start() -
buildPutKeyValueCommand
public PutKeyValueCommand buildPutKeyValueCommand(Object key, Object value, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) - Specified by:
buildPutKeyValueCommand
in interfaceCommandsFactory
-
buildRemoveCommand
public RemoveCommand buildRemoveCommand(Object key, Object value, int segment, long flagsBitSet, boolean returnEntry) - Specified by:
buildRemoveCommand
in interfaceCommandsFactory
-
buildInvalidateCommand
Description copied from interface:CommandsFactory
Builds an InvalidateCommand- Specified by:
buildInvalidateCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cachekeys
- keys to invalidate- Returns:
- an InvalidateCommand
-
buildInvalidateFromL1Command
Description copied from interface:CommandsFactory
Builds an InvalidateFromL1Command- Specified by:
buildInvalidateFromL1Command
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cachekeys
- keys to invalidate- Returns:
- an InvalidateFromL1Command
-
buildInvalidateFromL1Command
public InvalidateCommand buildInvalidateFromL1Command(Address origin, long flagsBitSet, Collection<Object> keys) - Specified by:
buildInvalidateFromL1Command
in interfaceCommandsFactory
- See Also:
-
buildRemoveExpiredCommand
public RemoveExpiredCommand buildRemoveExpiredCommand(Object key, Object value, int segment, Long lifespan, long flagsBitSet) Description copied from interface:CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via lifespan- Specified by:
buildRemoveExpiredCommand
in interfaceCommandsFactory
- Parameters:
key
- the key of the expired entryvalue
- the value of the entry when it was expiredsegment
- the segment of the given keylifespan
- the lifespan that expired from the commandflagsBitSet
- Command flags provided by cache- Returns:
- a RemovedExpiredCommand
-
buildRemoveExpiredCommand
public RemoveExpiredCommand buildRemoveExpiredCommand(Object key, Object value, int segment, long flagsBitSet) Description copied from interface:CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via maxIdle- Specified by:
buildRemoveExpiredCommand
in interfaceCommandsFactory
- Parameters:
key
- the key of the expired entryvalue
- the value of the entry when it was expiredsegment
- the segment of the given keyflagsBitSet
- Command flags provided by cache- Returns:
- a RemovedExpiredCommand
-
buildReplaceCommand
public ReplaceCommand buildReplaceCommand(Object key, Object oldValue, Object newValue, int segment, Metadata metadata, long flagsBitSet, boolean returnEntry) Description copied from interface:CommandsFactory
Builds a ReplaceCommand- Specified by:
buildReplaceCommand
in interfaceCommandsFactory
- Parameters:
key
- key to replaceoldValue
- existing value to check for if conditional, null if unconditional.newValue
- value to replace withsegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cachereturnEntry
- true if theCacheEntry
is the command response, otherwise returns previous value.- Returns:
- a ReplaceCommand
-
buildComputeCommand
public ComputeCommand buildComputeCommand(Object key, BiFunction mappingFunction, boolean computeIfPresent, int segment, Metadata metadata, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a ComputeCommand- Specified by:
buildComputeCommand
in interfaceCommandsFactory
- Parameters:
key
- key to compute if this key is absentmappingFunction
- BiFunction for the key and the valuecomputeIfPresent
- flag to apply as computeIfPresent modesegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a ComputeCommand
-
buildComputeIfAbsentCommand
public ComputeIfAbsentCommand buildComputeIfAbsentCommand(Object key, Function mappingFunction, int segment, Metadata metadata, long flagsBitSet) Description copied from interface:CommandsFactory
Builds a ComputeIfAbsentCommand- Specified by:
buildComputeIfAbsentCommand
in interfaceCommandsFactory
- Parameters:
key
- key to compute if this key is absentmappingFunction
- mappingFunction for the keysegment
- the segment of the given keymetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a ComputeCommand
-
buildSizeCommand
Description copied from interface:CommandsFactory
Builds a SizeCommand- Specified by:
buildSizeCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a SizeCommand
-
buildKeySetCommand
Description copied from interface:CommandsFactory
Builds a KeySetCommand- Specified by:
buildKeySetCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a KeySetCommand
-
buildEntrySetCommand
Description copied from interface:CommandsFactory
Builds a EntrySetCommand- Specified by:
buildEntrySetCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a EntrySetCommand
-
buildGetKeyValueCommand
Description copied from interface:CommandsFactory
Builds a GetKeyValueCommand- Specified by:
buildGetKeyValueCommand
in interfaceCommandsFactory
- Parameters:
key
- key to getsegment
- the segment of the given keyflagsBitSet
- Command flags provided by cache- Returns:
- a GetKeyValueCommand
-
buildGetAllCommand
public GetAllCommand buildGetAllCommand(Collection<?> keys, long flagsBitSet, boolean returnEntries) Description copied from interface:CommandsFactory
Builds a GetAllCommand- Specified by:
buildGetAllCommand
in interfaceCommandsFactory
- Parameters:
keys
- keys to getflagsBitSet
- Command flags provided by cachereturnEntries
- boolean indicating whether entire cache entries are returned, otherwise return just the value parts- Returns:
- a GetKeyValueCommand
-
buildPutMapCommand
Description copied from interface:CommandsFactory
Builds a PutMapCommand- Specified by:
buildPutMapCommand
in interfaceCommandsFactory
- Parameters:
map
- map containing key/value entries to putmetadata
- metadata of entryflagsBitSet
- Command flags provided by cache- Returns:
- a PutMapCommand
-
buildClearCommand
Description copied from interface:CommandsFactory
Builds a ClearCommand- Specified by:
buildClearCommand
in interfaceCommandsFactory
- Parameters:
flagsBitSet
- Command flags provided by cache- Returns:
- a ClearCommand
-
buildEvictCommand
Description copied from interface:CommandsFactory
Builds an EvictCommand- Specified by:
buildEvictCommand
in interfaceCommandsFactory
- Parameters:
key
- key to evictsegment
- the segment for the keyflagsBitSet
- Command flags provided by cache- Returns:
- an EvictCommand
-
buildPrepareCommand
public PrepareCommand buildPrepareCommand(GlobalTransaction gtx, List<WriteCommand> modifications, boolean onePhaseCommit) Description copied from interface:CommandsFactory
Builds a PrepareCommand- Specified by:
buildPrepareCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the preparemodifications
- list of modificationsonePhaseCommit
- is this a one-phase or two-phase transaction?- Returns:
- a PrepareCommand
-
buildVersionedPrepareCommand
public VersionedPrepareCommand buildVersionedPrepareCommand(GlobalTransaction gtx, List<WriteCommand> modifications, boolean onePhase) Description copied from interface:CommandsFactory
Builds a VersionedPrepareCommand- Specified by:
buildVersionedPrepareCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the preparemodifications
- list of modificationsonePhase
-- Returns:
- a VersionedPrepareCommand
-
buildCommitCommand
Description copied from interface:CommandsFactory
Builds a CommitCommand- Specified by:
buildCommitCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the commit- Returns:
- a CommitCommand
-
buildVersionedCommitCommand
Description copied from interface:CommandsFactory
Builds a VersionedCommitCommand- Specified by:
buildVersionedCommitCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the commit- Returns:
- a VersionedCommitCommand
-
buildRollbackCommand
Description copied from interface:CommandsFactory
Builds a RollbackCommand- Specified by:
buildRollbackCommand
in interfaceCommandsFactory
- Parameters:
gtx
- global transaction associated with the rollback- Returns:
- a RollbackCommand
-
buildSingleRpcCommand
Description copied from interface:CommandsFactory
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand- Specified by:
buildSingleRpcCommand
in interfaceCommandsFactory
- Parameters:
call
- VisitableCommand to include in the envelope- Returns:
- a SingleRpcCommand
-
buildClusteredGetCommand
Description copied from interface:CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command- Specified by:
buildClusteredGetCommand
in interfaceCommandsFactory
- Parameters:
key
- key to look upsegment
- the segment for the key or null if it should be computed on the remote nodeflagsBitSet
- Command flags provided by cache- Returns:
- a ClusteredGetCommand
-
initializeReplicableCommand
Description copied from interface:CommandsFactory
Initializes aReplicableCommand
read from a data stream with components specific to the target cache instance. Implementations should also be deep, in that if the command contains other commands, these should be recursed into.- Specified by:
initializeReplicableCommand
in interfaceCommandsFactory
- Parameters:
c
- command to initialize. Cannot be null.isRemote
- true if the command is deserialized and is executed remote.
-
buildLockControlCommand
public LockControlCommand buildLockControlCommand(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx) Description copied from interface:CommandsFactory
Builds a LockControlCommand to control explicit remote locking- Specified by:
buildLockControlCommand
in interfaceCommandsFactory
- Parameters:
keys
- keys to lockflagsBitSet
- Command flags provided by cachegtx
-- Returns:
- a LockControlCommand
-
buildLockControlCommand
public LockControlCommand buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx) Description copied from interface:CommandsFactory
Same asCommandsFactory.buildLockControlCommand(Collection, long, GlobalTransaction)
but for locking a single key vs a collection of keys.- Specified by:
buildLockControlCommand
in interfaceCommandsFactory
-
buildLockControlCommand
- Specified by:
buildLockControlCommand
in interfaceCommandsFactory
-
buildConflictResolutionStartCommand
public ConflictResolutionStartCommand buildConflictResolutionStartCommand(int topologyId, org.infinispan.commons.util.IntSet segments) - Specified by:
buildConflictResolutionStartCommand
in interfaceCommandsFactory
-
buildStateTransferCancelCommand
public StateTransferCancelCommand buildStateTransferCancelCommand(int topologyId, org.infinispan.commons.util.IntSet segments) - Specified by:
buildStateTransferCancelCommand
in interfaceCommandsFactory
-
buildStateTransferGetListenersCommand
- Specified by:
buildStateTransferGetListenersCommand
in interfaceCommandsFactory
-
buildStateTransferGetTransactionsCommand
public StateTransferGetTransactionsCommand buildStateTransferGetTransactionsCommand(int topologyId, org.infinispan.commons.util.IntSet segments) - Specified by:
buildStateTransferGetTransactionsCommand
in interfaceCommandsFactory
-
buildStateTransferStartCommand
public StateTransferStartCommand buildStateTransferStartCommand(int topologyId, org.infinispan.commons.util.IntSet segments) - Specified by:
buildStateTransferStartCommand
in interfaceCommandsFactory
-
buildStateResponseCommand
public StateResponseCommand buildStateResponseCommand(int topologyId, Collection<StateChunk> stateChunks, boolean applyState) Description copied from interface:CommandsFactory
Builds a StateResponseCommand used for pushing cache entries to another node.- Specified by:
buildStateResponseCommand
in interfaceCommandsFactory
-
getCacheName
Description copied from interface:CommandsFactory
Retrieves the cache name this CommandFactory is set up to construct commands for.- Specified by:
getCacheName
in interfaceCommandsFactory
- Returns:
- the name of the cache this CommandFactory is set up to construct commands for.
-
buildGetInDoubtTransactionsCommand
Description copied from interface:CommandsFactory
Builds aGetInDoubtTransactionsCommand
.- Specified by:
buildGetInDoubtTransactionsCommand
in interfaceCommandsFactory
-
buildTxCompletionNotificationCommand
public TxCompletionNotificationCommand buildTxCompletionNotificationCommand(org.infinispan.commons.tx.XidImpl xid, GlobalTransaction globalTransaction) Description copied from interface:CommandsFactory
Builds aTxCompletionNotificationCommand
.- Specified by:
buildTxCompletionNotificationCommand
in interfaceCommandsFactory
-
buildTxCompletionNotificationCommand
- Specified by:
buildTxCompletionNotificationCommand
in interfaceCommandsFactory
- Parameters:
internalId
- the internal id identifying the transaction to be removed.- See Also:
-
buildGetInDoubtTxInfoCommand
- Specified by:
buildGetInDoubtTxInfoCommand
in interfaceCommandsFactory
- See Also:
-
buildCompleteTransactionCommand
public CompleteTransactionCommand buildCompleteTransactionCommand(org.infinispan.commons.tx.XidImpl xid, boolean commit) Description copied from interface:CommandsFactory
Builds a CompleteTransactionCommand command.- Specified by:
buildCompleteTransactionCommand
in interfaceCommandsFactory
- Parameters:
xid
- the xid identifying the transaction we want to complete.commit
- commit(true) or rollback(false)?
-
buildXSiteStateTransferCancelSendCommand
public XSiteStateTransferCancelSendCommand buildXSiteStateTransferCancelSendCommand(String siteName) - Specified by:
buildXSiteStateTransferCancelSendCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferClearStatusCommand
- Specified by:
buildXSiteStateTransferClearStatusCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferFinishReceiveCommand
public XSiteStateTransferFinishReceiveCommand buildXSiteStateTransferFinishReceiveCommand(String siteName) - Specified by:
buildXSiteStateTransferFinishReceiveCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferFinishSendCommand
public XSiteStateTransferFinishSendCommand buildXSiteStateTransferFinishSendCommand(String siteName, boolean statusOk) - Specified by:
buildXSiteStateTransferFinishSendCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferRestartSendingCommand
public XSiteStateTransferRestartSendingCommand buildXSiteStateTransferRestartSendingCommand(String siteName, int topologyId) - Specified by:
buildXSiteStateTransferRestartSendingCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferStartReceiveCommand
public XSiteStateTransferStartReceiveCommand buildXSiteStateTransferStartReceiveCommand(String siteName) - Specified by:
buildXSiteStateTransferStartReceiveCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferStartSendCommand
public XSiteStateTransferStartSendCommand buildXSiteStateTransferStartSendCommand(String siteName, int topologyId) - Specified by:
buildXSiteStateTransferStartSendCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferStatusRequestCommand
- Specified by:
buildXSiteStateTransferStatusRequestCommand
in interfaceCommandsFactory
-
buildXSiteStateTransferControlRequest
public XSiteStateTransferControlRequest buildXSiteStateTransferControlRequest(boolean startReceiving) - Specified by:
buildXSiteStateTransferControlRequest
in interfaceCommandsFactory
-
buildXSiteAmendOfflineStatusCommand
public XSiteAmendOfflineStatusCommand buildXSiteAmendOfflineStatusCommand(String siteName, Integer afterFailures, Long minTimeToWait) - Specified by:
buildXSiteAmendOfflineStatusCommand
in interfaceCommandsFactory
-
buildXSiteBringOnlineCommand
- Specified by:
buildXSiteBringOnlineCommand
in interfaceCommandsFactory
-
buildXSiteOfflineStatusCommand
- Specified by:
buildXSiteOfflineStatusCommand
in interfaceCommandsFactory
-
buildXSiteStatusCommand
- Specified by:
buildXSiteStatusCommand
in interfaceCommandsFactory
-
buildXSiteTakeOfflineCommand
- Specified by:
buildXSiteTakeOfflineCommand
in interfaceCommandsFactory
-
buildXSiteStatePushCommand
Description copied from interface:CommandsFactory
Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.- Specified by:
buildXSiteStatePushCommand
in interfaceCommandsFactory
- Parameters:
chunk
- the data chunk- Returns:
- the XSiteStatePushCommand created
-
buildSingleXSiteRpcCommand
Description copied from interface:CommandsFactory
Builds SingleRpcCommand used to performVisitableCommand
on the backup site,- Specified by:
buildSingleXSiteRpcCommand
in interfaceCommandsFactory
- Parameters:
command
- the visitable command.- Returns:
- the SingleXSiteRpcCommand created
-
buildGetCacheEntryCommand
Description copied from interface:CommandsFactory
Builds a GetCacheEntryCommand- Specified by:
buildGetCacheEntryCommand
in interfaceCommandsFactory
- Parameters:
key
- key to getsegment
- the segment for the keyflagsBitSet
- Command flags provided by cache- Returns:
- a GetCacheEntryCommand
-
buildClusteredGetAllCommand
public ClusteredGetAllCommand buildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx) Description copied from interface:CommandsFactory
Builds a ClusteredGetAllCommand, which is a remote lookup command- Specified by:
buildClusteredGetAllCommand
in interfaceCommandsFactory
- Parameters:
keys
- key to look upflagsBitSet
- Command flags provided by cache- Returns:
- a ClusteredGetAllCommand
-
buildReadOnlyKeyCommand
public <K,V, ReadOnlyKeyCommand<K,R> V, buildReadOnlyKeyCommandR> (Object key, Function<EntryView.ReadEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadOnlyKeyCommand
in interfaceCommandsFactory
-
buildReadOnlyManyCommand
public <K,V, ReadOnlyManyCommand<K,R> V, buildReadOnlyManyCommandR> (Collection<?> keys, Function<EntryView.ReadEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadOnlyManyCommand
in interfaceCommandsFactory
-
buildReadWriteKeyValueCommand
public <K,V, ReadWriteKeyValueCommand<K,T, R> V, buildReadWriteKeyValueCommandT, R> (Object key, Object argument, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteKeyValueCommand
in interfaceCommandsFactory
-
buildReadWriteKeyCommand
public <K,V, ReadWriteKeyCommand<K,R> V, buildReadWriteKeyCommandR> (Object key, Function<EntryView.ReadWriteEntryView<K, V>, R> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteKeyCommand
in interfaceCommandsFactory
-
buildReadWriteManyCommand
public <K,V, ReadWriteManyCommand<K,R> V, buildReadWriteManyCommandR> (Collection<?> keys, Function<EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteManyCommand
in interfaceCommandsFactory
-
buildReadWriteManyEntriesCommand
public <K,V, ReadWriteManyEntriesCommand<K,T, R> V, buildReadWriteManyEntriesCommandT, R> (Map<?, ?> entries, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildReadWriteManyEntriesCommand
in interfaceCommandsFactory
-
buildWriteOnlyKeyCommand
public <K,V> WriteOnlyKeyCommand<K,V> buildWriteOnlyKeyCommand(Object key, Consumer<EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyKeyCommand
in interfaceCommandsFactory
-
buildWriteOnlyKeyValueCommand
public <K,V, WriteOnlyKeyValueCommand<K,T> V, buildWriteOnlyKeyValueCommandT> (Object key, Object argument, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyKeyValueCommand
in interfaceCommandsFactory
-
buildWriteOnlyManyCommand
public <K,V> WriteOnlyManyCommand<K,V> buildWriteOnlyManyCommand(Collection<?> keys, Consumer<EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyManyCommand
in interfaceCommandsFactory
-
buildWriteOnlyManyEntriesCommand
public <K,V, WriteOnlyManyEntriesCommand<K,T> V, buildWriteOnlyManyEntriesCommandT> (Map<?, ?> arguments, BiConsumer<T, EntryView.WriteEntryView<K, V>> f, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildWriteOnlyManyEntriesCommand
in interfaceCommandsFactory
-
buildTxReadOnlyKeyCommand
public <K,V, TxReadOnlyKeyCommand<K,R> V, buildTxReadOnlyKeyCommandR> (Object key, Function<EntryView.ReadEntryView<K, V>, R> f, List<Mutation<K, V, ?>> mutations, int segment, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildTxReadOnlyKeyCommand
in interfaceCommandsFactory
-
buildTxReadOnlyManyCommand
public <K,V, TxReadOnlyManyCommand<K,R> V, buildTxReadOnlyManyCommandR> (Collection<?> keys, List<List<Mutation<K, V, ?>>> mutations, Params params, DataConversion keyDataConversion, DataConversion valueDataConversion) - Specified by:
buildTxReadOnlyManyCommand
in interfaceCommandsFactory
-
buildBackupMultiKeyAckCommand
- Specified by:
buildBackupMultiKeyAckCommand
in interfaceCommandsFactory
-
buildExceptionAckCommand
- Specified by:
buildExceptionAckCommand
in interfaceCommandsFactory
-
buildSingleKeyBackupWriteCommand
- Specified by:
buildSingleKeyBackupWriteCommand
in interfaceCommandsFactory
-
buildSingleKeyFunctionalBackupWriteCommand
- Specified by:
buildSingleKeyFunctionalBackupWriteCommand
in interfaceCommandsFactory
-
buildPutMapBackupWriteCommand
- Specified by:
buildPutMapBackupWriteCommand
in interfaceCommandsFactory
-
buildMultiEntriesFunctionalBackupWriteCommand
- Specified by:
buildMultiEntriesFunctionalBackupWriteCommand
in interfaceCommandsFactory
-
buildMultiKeyFunctionalBackupWriteCommand
- Specified by:
buildMultiKeyFunctionalBackupWriteCommand
in interfaceCommandsFactory
-
buildBackupNoopCommand
- Specified by:
buildBackupNoopCommand
in interfaceCommandsFactory
-
buildKeyReductionPublisherCommand
public <K,R> ReductionPublisherRequestCommand<K> buildKeyReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) - Specified by:
buildKeyReductionPublisherCommand
in interfaceCommandsFactory
-
buildEntryReductionPublisherCommand
public <K,V, ReductionPublisherRequestCommand<K> buildEntryReductionPublisherCommandR> (boolean parallelStream, DeliveryGuarantee deliveryGuarantee, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) - Specified by:
buildEntryReductionPublisherCommand
in interfaceCommandsFactory
-
buildInitialPublisherCommand
public <K,I, InitialPublisherCommand<K,R> I, buildInitialPublisherCommandR> (String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, org.infinispan.commons.util.IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>, ? extends org.reactivestreams.Publisher<R>> transformer) - Specified by:
buildInitialPublisherCommand
in interfaceCommandsFactory
-
buildNextPublisherCommand
- Specified by:
buildNextPublisherCommand
in interfaceCommandsFactory
-
buildCancelPublisherCommand
- Specified by:
buildCancelPublisherCommand
in interfaceCommandsFactory
-
buildMultiClusterEventCommand
public <K,V> MultiClusterEventCommand<K,V> buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>> events) - Specified by:
buildMultiClusterEventCommand
in interfaceCommandsFactory
-
buildCheckTransactionRpcCommand
public CheckTransactionRpcCommand buildCheckTransactionRpcCommand(Collection<GlobalTransaction> globalTransactions) - Specified by:
buildCheckTransactionRpcCommand
in interfaceCommandsFactory
-
buildTouchCommand
public TouchCommand buildTouchCommand(Object key, int segment, boolean touchEvenIfExpired, long flagBitSet) - Specified by:
buildTouchCommand
in interfaceCommandsFactory
-
buildIracClearKeysCommand
- Specified by:
buildIracClearKeysCommand
in interfaceCommandsFactory
-
buildIracCleanupKeyCommand
- Specified by:
buildIracCleanupKeyCommand
in interfaceCommandsFactory
-
buildIracTombstoneCleanupCommand
- Specified by:
buildIracTombstoneCleanupCommand
in interfaceCommandsFactory
-
buildIracMetadataRequestCommand
public IracMetadataRequestCommand buildIracMetadataRequestCommand(int segment, IracEntryVersion versionSeen) - Specified by:
buildIracMetadataRequestCommand
in interfaceCommandsFactory
-
buildIracRequestStateCommand
public IracRequestStateCommand buildIracRequestStateCommand(org.infinispan.commons.util.IntSet segments) - Specified by:
buildIracRequestStateCommand
in interfaceCommandsFactory
-
buildIracStateResponseCommand
- Specified by:
buildIracStateResponseCommand
in interfaceCommandsFactory
-
buildIracPutKeyValueCommand
public IracPutKeyValueCommand buildIracPutKeyValueCommand(Object key, int segment, Object value, Metadata metadata, PrivateMetadata privateMetadata) - Specified by:
buildIracPutKeyValueCommand
in interfaceCommandsFactory
-
buildIracTouchCommand
- Specified by:
buildIracTouchCommand
in interfaceCommandsFactory
-
buildIracUpdateVersionCommand
public IracUpdateVersionCommand buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion> segmentsVersion) - Specified by:
buildIracUpdateVersionCommand
in interfaceCommandsFactory
-
buildXSiteAutoTransferStatusCommand
- Specified by:
buildXSiteAutoTransferStatusCommand
in interfaceCommandsFactory
-
buildXSiteSetStateTransferModeCommand
public XSiteSetStateTransferModeCommand buildXSiteSetStateTransferModeCommand(String site, XSiteStateTransferMode mode) - Specified by:
buildXSiteSetStateTransferModeCommand
in interfaceCommandsFactory
-
buildIracTombstoneRemoteSiteCheckCommand
public IracTombstoneRemoteSiteCheckCommand buildIracTombstoneRemoteSiteCheckCommand(List<Object> keys) - Specified by:
buildIracTombstoneRemoteSiteCheckCommand
in interfaceCommandsFactory
-
buildIracTombstoneStateResponseCommand
public IracTombstoneStateResponseCommand buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo> state) - Specified by:
buildIracTombstoneStateResponseCommand
in interfaceCommandsFactory
-
buildIracTombstonePrimaryCheckCommand
public IracTombstonePrimaryCheckCommand buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo> tombstones) - Specified by:
buildIracTombstonePrimaryCheckCommand
in interfaceCommandsFactory
-
buildIracPutManyCommand
- Specified by:
buildIracPutManyCommand
in interfaceCommandsFactory
-
buildXSiteStatePushRequest
- Specified by:
buildXSiteStatePushRequest
in interfaceCommandsFactory
-
buildIracTombstoneCheckRequest
- Specified by:
buildIracTombstoneCheckRequest
in interfaceCommandsFactory
-