Uses of Interface
org.infinispan.context.InvocationContext
-
Packages that use InvocationContext Package Description org.infinispan.commands Commands that operate on the cache, either locally or remotely.org.infinispan.commands.control org.infinispan.commands.functional org.infinispan.commands.read org.infinispan.commands.remote Meta-commands that wrap other commands for remote execution.org.infinispan.commands.remote.recovery org.infinispan.commands.tx Commands that represent transactional lifecycle transitions.org.infinispan.commands.write Commands that alter the state of the cache.org.infinispan.context Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags.org.infinispan.interceptors Infinispan is designed around a set of interceptors around a data container.org.infinispan.interceptors.base Base interceptors containing common, reusable behavior.org.infinispan.interceptors.distribution Interceptors dealing with command replication in distributed/replicated mode.org.infinispan.interceptors.locking Interceptors dealing with locking.org.infinispan.interceptors.totalorder Interceptors dealing with total order.org.infinispan.interceptors.xsite Interceptors dealing with cross-site replication.org.infinispan.notifications.cachelistener Cache
-specific notifications and eventing.org.infinispan.persistence Persistence API.org.infinispan.persistence.internal org.infinispan.query.backend Mostly internal search related classes.org.infinispan.statetransfer Transfer of state to new caches in a cluster.org.infinispan.stats.topK org.infinispan.stats.wrappers org.infinispan.util.concurrent.locks Lock and synchronization related classes, tools and utilities. -
-
Uses of InvocationContext in org.infinispan.commands
-
Uses of InvocationContext in org.infinispan.commands.control
Methods in org.infinispan.commands.control with parameters of type InvocationContext Modifier and Type Method Description Object
LockControlCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
-
Uses of InvocationContext in org.infinispan.commands.functional
Methods in org.infinispan.commands.functional with parameters of type InvocationContext Modifier and Type Method Description Object
ReadOnlyKeyCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ReadOnlyManyCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ReadWriteKeyCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ReadWriteKeyValueCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ReadWriteManyCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ReadWriteManyEntriesCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
WriteOnlyKeyCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
WriteOnlyKeyValueCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
WriteOnlyManyCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
WriteOnlyManyEntriesCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
protected CacheEntry
ReadOnlyManyCommand. lookupCacheEntry(InvocationContext ctx, Object key)
Object
ReadOnlyKeyCommand. perform(InvocationContext ctx)
Object
ReadOnlyManyCommand. perform(InvocationContext ctx)
Object
ReadWriteKeyCommand. perform(InvocationContext ctx)
Object
ReadWriteKeyValueCommand. perform(InvocationContext ctx)
Object
ReadWriteManyCommand. perform(InvocationContext ctx)
Object
ReadWriteManyEntriesCommand. perform(InvocationContext ctx)
Object
TxReadOnlyKeyCommand. perform(InvocationContext ctx)
Object
TxReadOnlyManyCommand. perform(InvocationContext ctx)
Object
WriteOnlyKeyCommand. perform(InvocationContext ctx)
Object
WriteOnlyKeyValueCommand. perform(InvocationContext ctx)
Object
WriteOnlyManyCommand. perform(InvocationContext ctx)
Object
WriteOnlyManyEntriesCommand. perform(InvocationContext ctx)
-
Uses of InvocationContext in org.infinispan.commands.read
-
Uses of InvocationContext in org.infinispan.commands.remote
Methods in org.infinispan.commands.remote with parameters of type InvocationContext Modifier and Type Method Description Object
GetKeysInGroupCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
GetKeysInGroupCommand. perform(InvocationContext ctx)
Object
SingleRpcCommand. perform(InvocationContext ctx)
-
Uses of InvocationContext in org.infinispan.commands.remote.recovery
Methods in org.infinispan.commands.remote.recovery with parameters of type InvocationContext Modifier and Type Method Description List<Xid>
GetInDoubtTransactionsCommand. perform(InvocationContext ctx)
-
Uses of InvocationContext in org.infinispan.commands.tx
Methods in org.infinispan.commands.tx with parameters of type InvocationContext Modifier and Type Method Description Object
CommitCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
PrepareCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
RollbackCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
AbstractTransactionBoundaryCommand. perform(InvocationContext ctx)
-
Uses of InvocationContext in org.infinispan.commands.write
Methods in org.infinispan.commands.write with parameters of type InvocationContext Modifier and Type Method Description Object
ApplyDeltaCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Deprecated.Object
ClearCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ComputeCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ComputeIfAbsentCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
EvictCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
InvalidateCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
InvalidateL1Command. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
PutKeyValueCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
PutMapCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
RemoveCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
RemoveExpiredCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
Object
ReplaceCommand. acceptVisitor(InvocationContext ctx, Visitor visitor)
void
EvictCommand. notify(InvocationContext ctx, Object value, Metadata previousMetadata, boolean isPre)
protected void
InvalidateCommand. notify(InvocationContext ctx, MVCCEntry e, boolean pre)
void
RemoveCommand. notify(InvocationContext ctx, Object removedValue, Metadata removedMetadata, boolean isPre)
void
RemoveExpiredCommand. notify(InvocationContext ctx, Object removedValue, Metadata removedMetadata, boolean isPre)
Object
ApplyDeltaCommand. perform(InvocationContext ctx)
Deprecated.Performs an application of delta on a specified entryObject
ClearCommand. perform(InvocationContext ctx)
Object
ComputeCommand. perform(InvocationContext ctx)
Object
ComputeIfAbsentCommand. perform(InvocationContext ctx)
Object
EvictCommand. perform(InvocationContext ctx)
Object
InvalidateCommand. perform(InvocationContext ctx)
Performs an invalidation on a specified entryObject
InvalidateL1Command. perform(InvocationContext ctx)
Object
PutKeyValueCommand. perform(InvocationContext ctx)
Object
PutMapCommand. perform(InvocationContext ctx)
Object
RemoveCommand. perform(InvocationContext ctx)
Object
RemoveExpiredCommand. perform(InvocationContext ctx)
Performs an expiration on a specified entryObject
ReplaceCommand. perform(InvocationContext ctx)
protected Object
RemoveCommand. performRemove(MVCCEntry e, Object prevValue, InvocationContext ctx)
-
Uses of InvocationContext in org.infinispan.context
Classes in org.infinispan.context that implement InvocationContext Modifier and Type Class Description class
SingleKeyNonTxInvocationContext
Deprecated.Since 9.0, this class is going to be moved to an internal package.Methods in org.infinispan.context that return InvocationContext Modifier and Type Method Description InvocationContext
InvocationContext. clone()
Clones the invocation context.InvocationContext
SingleKeyNonTxInvocationContext. clone()
Deprecated.InvocationContext
AbstractInvocationContextFactory. createClearNonTxInvocationContext()
Deprecated.InvocationContext
InvocationContextFactory. createClearNonTxInvocationContext()
Will create anClearInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true.InvocationContext
InvocationContextFactory. createInvocationContext(boolean isWrite, int keyCount)
If we are in a tx scope this will return anTxInvocationContext
.InvocationContext
InvocationContextFactory. createInvocationContext(Transaction tx, boolean implicitTransaction)
Creates an invocation contextInvocationContext
NonTransactionalInvocationContextFactory. createInvocationContext(boolean isWrite, int keyCount)
Deprecated.InvocationContext
NonTransactionalInvocationContextFactory. createInvocationContext(Transaction tx, boolean implicitTransaction)
Deprecated.InvocationContext
TransactionalInvocationContextFactory. createInvocationContext(boolean isWrite, int keyCount)
Deprecated.InvocationContext
TransactionalInvocationContextFactory. createInvocationContext(Transaction tx, boolean implicitTransaction)
Deprecated.InvocationContext
InvocationContextFactory. createRemoteInvocationContext(Address origin)
Returns anNonTxInvocationContext
whoseAbstractInvocationContext.isOriginLocal()
flag will be true.InvocationContext
AbstractInvocationContextFactory. createRemoteInvocationContextForCommand(VisitableCommand cacheCommand, Address origin)
Deprecated.InvocationContext
InvocationContextFactory. createRemoteInvocationContextForCommand(VisitableCommand cacheCommand, Address origin)
AsInvocationContextFactory.createRemoteInvocationContext(org.infinispan.remoting.transport.Address)
, but returning the flags to the context from the Command if any Flag was set.InvocationContext
InvocationContextFactory. createSingleKeyNonTxInvocationContext()
Will create anNonTxInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true.InvocationContext
NonTransactionalInvocationContextFactory. createSingleKeyNonTxInvocationContext()
Deprecated.InvocationContext
TransactionalInvocationContextFactory. createSingleKeyNonTxInvocationContext()
Deprecated.InvocationContext
InvocationContextContainer. getInvocationContext(boolean quiet)
Deprecated.Returns theInvocationContext
that is currently associated with the calling thread.Methods in org.infinispan.context with parameters of type InvocationContext Modifier and Type Method Description default void
InvocationContextContainer. clearThreadLocal(InvocationContext context)
Deprecated.void
InvocationContextContainer. setThreadLocal(InvocationContext context)
Deprecated.Associate the InvocationContext parameter with the calling thread. -
Uses of InvocationContext in org.infinispan.interceptors
Methods in org.infinispan.interceptors with parameters of type InvocationContext Modifier and Type Method Description void
InvocationFinallyAction. accept(InvocationContext rCtx, VisitableCommand rCommand, Object rv, Throwable throwable)
Process the result or the exception from an invocation stage and possibly throw an exception.void
InvocationSuccessAction. accept(InvocationContext rCtx, VisitableCommand rCommand, Object rv)
Process the result from a successful invocation stage and possibly throw an exception.abstract Object
InvocationStage. addCallback(InvocationContext ctx, VisitableCommand command, InvocationCallback function)
Object
SyncInvocationStage. addCallback(InvocationContext ctx, VisitableCommand command, InvocationCallback function)
Object
InvocationStage. andExceptionally(InvocationContext ctx, VisitableCommand command, InvocationExceptionFunction function)
Object
InvocationStage. andFinally(InvocationContext ctx, VisitableCommand command, InvocationFinallyAction action)
Object
InvocationStage. andHandle(InvocationContext ctx, VisitableCommand command, InvocationFinallyFunction function)
Object
InvocationCallback. apply(InvocationContext rCtx, VisitableCommand rCommand, Object rv, Throwable throwable)
Process the result or the exception from an invocation stage and either return a simple value, return a newInvocationStage
, or throw an exception.default Object
InvocationExceptionFunction. apply(InvocationContext rCtx, VisitableCommand rCommand, Object rv, Throwable throwable)
Object
InvocationExceptionFunction. apply(InvocationContext rCtx, VisitableCommand rCommand, Throwable throwable)
Process the result from a successful invocation stage and either return a simple value, return a newInvocationStage
, or throw an exception.default Object
InvocationFinallyAction. apply(InvocationContext rCtx, VisitableCommand rCommand, Object rv, Throwable throwable)
default Object
InvocationSuccessAction. apply(InvocationContext rCtx, VisitableCommand rCommand, Object rv, Throwable throwable)
Object
InvocationSuccessFunction. apply(InvocationContext rCtx, VisitableCommand rCommand, Object rv)
Process the result from a successful invocation stage and either return a simple value, return a newInvocationStage
, or throw an exception.default Object
InvocationSuccessFunction. apply(InvocationContext rCtx, VisitableCommand rCommand, Object rv, Throwable throwable)
Object
BaseAsyncInterceptor. asyncInvokeNext(InvocationContext ctx, VisitableCommand command, Collection<? extends CompletionStage<?>> delays)
Suspend invocation until alldelays
complete, then if successful invoke the next interceptor.Object
BaseAsyncInterceptor. asyncInvokeNext(InvocationContext ctx, VisitableCommand command, CompletionStage<?> delay)
Suspend the invocation untildelay
completes, then if successful invoke the next interceptor.Object
BaseAsyncInterceptor. asyncInvokeNext(InvocationContext ctx, VisitableCommand command, InvocationStage invocationStage)
Suspend the invocation untilinvocationStage
completes, then if successful invoke the next interceptor.protected Object
DDAsyncInterceptor. handleDefault(InvocationContext ctx, VisitableCommand command)
Object
AsyncInterceptorChain. invoke(InvocationContext ctx, VisitableCommand command)
Walks the command through the interceptor chain.Object
EmptyAsyncInterceptorChain. invoke(InvocationContext ctx, VisitableCommand command)
Object
InterceptorChain. invoke(InvocationContext ctx, VisitableCommand command)
Deprecated.Walks the command through the interceptor chain.CompletableFuture<Object>
AsyncInterceptorChain. invokeAsync(InvocationContext ctx, VisitableCommand command)
Walks the command through the interceptor chain.CompletableFuture<Object>
EmptyAsyncInterceptorChain. invokeAsync(InvocationContext ctx, VisitableCommand command)
Object
BaseAsyncInterceptor. invokeNext(InvocationContext ctx, VisitableCommand command)
Invoke the next interceptor, possibly with a new command.Object
BaseAsyncInterceptor. invokeNextAndExceptionally(InvocationContext ctx, VisitableCommand command, InvocationExceptionFunction function)
Invoke the next interceptor, possibly with a new command, and execute anInvocationCallback
after all the interceptors have finished with an exception.Object
BaseAsyncInterceptor. invokeNextAndFinally(InvocationContext ctx, VisitableCommand command, InvocationFinallyAction action)
Invoke the next interceptor, possibly with a new command, and execute anInvocationCallback
after all the interceptors have finished, with or without an exception.Object
BaseAsyncInterceptor. invokeNextAndHandle(InvocationContext ctx, VisitableCommand command, InvocationFinallyFunction function)
Invoke the next interceptor, possibly with a new command, and execute anInvocationCallback
after all the interceptors have finished, with or without an exception.Object
BaseAsyncInterceptor. invokeNextThenAccept(InvocationContext ctx, VisitableCommand command, InvocationSuccessAction action)
Invoke the next interceptor, possibly with a new command, and execute anInvocationCallback
after all the interceptors have finished successfully.Object
BaseAsyncInterceptor. invokeNextThenApply(InvocationContext ctx, VisitableCommand command, InvocationSuccessFunction function)
Invoke the next interceptor, possibly with a new command, and execute anInvocationCallback
after all the interceptors have finished successfully.Object
InvocationStage. thenAccept(InvocationContext ctx, VisitableCommand command, InvocationSuccessAction function)
Object
InvocationStage. thenApply(InvocationContext ctx, VisitableCommand command, InvocationSuccessFunction function)
After the current stage completes successfully, invokefunction
and return its result.Object
DDAsyncInterceptor. visitClearCommand(InvocationContext ctx, ClearCommand command)
Object
AsyncInterceptor. visitCommand(InvocationContext ctx, VisitableCommand command)
Perform some work for a command invocation.Object
DDAsyncInterceptor. visitCommand(InvocationContext ctx, VisitableCommand command)
Object
DDAsyncInterceptor. visitComputeCommand(InvocationContext ctx, ComputeCommand command)
Object
DDAsyncInterceptor. visitComputeIfAbsentCommand(InvocationContext ctx, ComputeIfAbsentCommand command)
<V> Object
DDAsyncInterceptor. visitDistributedExecuteCommand(InvocationContext ctx, DistributedExecuteCommand<V> command)
Object
DDAsyncInterceptor. visitEntrySetCommand(InvocationContext ctx, EntrySetCommand command)
Object
DDAsyncInterceptor. visitEvictCommand(InvocationContext ctx, EvictCommand command)
Object
DDAsyncInterceptor. visitGetAllCommand(InvocationContext ctx, GetAllCommand command)
Object
DDAsyncInterceptor. visitGetCacheEntryCommand(InvocationContext ctx, GetCacheEntryCommand command)
Object
DDAsyncInterceptor. visitGetKeysInGroupCommand(InvocationContext ctx, GetKeysInGroupCommand command)
Object
DDAsyncInterceptor. visitGetKeyValueCommand(InvocationContext ctx, GetKeyValueCommand command)
Object
DDAsyncInterceptor. visitInvalidateCommand(InvocationContext ctx, InvalidateCommand command)
Object
DDAsyncInterceptor. visitInvalidateL1Command(InvocationContext ctx, InvalidateL1Command command)
Object
DDAsyncInterceptor. visitKeySetCommand(InvocationContext ctx, KeySetCommand command)
Object
DDAsyncInterceptor. visitPutKeyValueCommand(InvocationContext ctx, PutKeyValueCommand command)
Object
DDAsyncInterceptor. visitPutMapCommand(InvocationContext ctx, PutMapCommand command)
Object
DDAsyncInterceptor. visitReadOnlyKeyCommand(InvocationContext ctx, ReadOnlyKeyCommand command)
Object
DDAsyncInterceptor. visitReadOnlyManyCommand(InvocationContext ctx, ReadOnlyManyCommand command)
Object
DDAsyncInterceptor. visitReadWriteKeyCommand(InvocationContext ctx, ReadWriteKeyCommand command)
Object
DDAsyncInterceptor. visitReadWriteKeyValueCommand(InvocationContext ctx, ReadWriteKeyValueCommand command)
Object
DDAsyncInterceptor. visitReadWriteManyCommand(InvocationContext ctx, ReadWriteManyCommand command)
Object
DDAsyncInterceptor. visitReadWriteManyEntriesCommand(InvocationContext ctx, ReadWriteManyEntriesCommand command)
Object
DDAsyncInterceptor. visitRemoveCommand(InvocationContext ctx, RemoveCommand command)
Object
DDAsyncInterceptor. visitReplaceCommand(InvocationContext ctx, ReplaceCommand command)
Object
DDAsyncInterceptor. visitSizeCommand(InvocationContext ctx, SizeCommand command)
Object
DDAsyncInterceptor. visitUnknownCommand(InvocationContext ctx, VisitableCommand command)
Object
DDAsyncInterceptor. visitWriteOnlyKeyCommand(InvocationContext ctx, WriteOnlyKeyCommand command)
Object
DDAsyncInterceptor. visitWriteOnlyKeyValueCommand(InvocationContext ctx, WriteOnlyKeyValueCommand command)
Object
DDAsyncInterceptor. visitWriteOnlyManyCommand(InvocationContext ctx, WriteOnlyManyCommand command)
Object
DDAsyncInterceptor. visitWriteOnlyManyEntriesCommand(InvocationContext ctx, WriteOnlyManyEntriesCommand command)
-
Uses of InvocationContext in org.infinispan.interceptors.base
Methods in org.infinispan.interceptors.base with parameters of type InvocationContext Modifier and Type Method Description protected abstract void
PrePostProcessingCommandInterceptor. doAfterCall(InvocationContext ctx, VisitableCommand command)
Deprecated.Callback that is invoked after every handleXXX() method defined above.protected boolean
PrePostProcessingCommandInterceptor. doBeforeCall(InvocationContext ctx, VisitableCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleClearCommand(InvocationContext ctx, ClearCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleCommitCommand(InvocationContext ctx, CommitCommand command)
Deprecated.protected Object
CommandInterceptor. handleDefault(InvocationContext ctx, VisitableCommand command)
Deprecated.The default behaviour of the visitXXX methods, which is to ignore the call and pass the call up to the next interceptor in the chain.protected Object
PrePostProcessingCommandInterceptor. handleEvictCommand(InvocationContext ctx, EvictCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleGetKeyValueCommand(InvocationContext ctx, GetKeyValueCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handlePrepareCommand(InvocationContext ctx, PrepareCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handlePutKeyValueCommand(InvocationContext ctx, PutKeyValueCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handlePutMapCommand(InvocationContext ctx, PutMapCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleRemoveCommand(InvocationContext ctx, RemoveCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleReplaceCommand(InvocationContext ctx, ReplaceCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleRollbackCommand(InvocationContext ctx, RollbackCommand command)
Deprecated.protected Object
PrePostProcessingCommandInterceptor. handleSizeCommand(InvocationContext ctx, SizeCommand command)
Deprecated.Object
CommandInterceptor. invokeNextInterceptor(InvocationContext ctx, VisitableCommand command)
Deprecated.Invokes the next interceptor in the chain.Object
PrePostProcessingCommandInterceptor. visitClearCommand(InvocationContext ctx, ClearCommand command)
Deprecated.Object
CommandInterceptor. visitCommand(InvocationContext ctx, VisitableCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitComputeCommand(InvocationContext ctx, ComputeCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitComputeIfAbsentCommand(InvocationContext ctx, ComputeIfAbsentCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitEvictCommand(InvocationContext ctx, EvictCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitGetKeyValueCommand(InvocationContext ctx, GetKeyValueCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitPutKeyValueCommand(InvocationContext ctx, PutKeyValueCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitPutMapCommand(InvocationContext ctx, PutMapCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitRemoveCommand(InvocationContext ctx, RemoveCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitReplaceCommand(InvocationContext ctx, ReplaceCommand command)
Deprecated.Object
PrePostProcessingCommandInterceptor. visitSizeCommand(InvocationContext ctx, SizeCommand command)
Deprecated. -
Uses of InvocationContext in org.infinispan.interceptors.distribution
-
Uses of InvocationContext in org.infinispan.interceptors.locking
Methods in org.infinispan.interceptors.locking with parameters of type InvocationContext Modifier and Type Method Description protected ClusteringDependentLogic.Commit
ClusteringDependentLogic.AbstractClusteringDependentLogic. clusterCommitType(FlagAffectedCommand command, InvocationContext ctx, int segment, boolean removed)
void
ClusteringDependentLogic.AbstractClusteringDependentLogic. commitEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
void
ClusteringDependentLogic. commitEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
protected abstract void
ClusteringDependentLogic.AbstractClusteringDependentLogic. commitSingleEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
protected void
ClusteringDependentLogic.DistributionLogic. commitSingleEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
protected void
ClusteringDependentLogic.InvalidationLogic. commitSingleEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
protected void
ClusteringDependentLogic.LocalLogic. commitSingleEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
protected void
ClusteringDependentLogic.ReplicationLogic. commitSingleEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
protected void
ClusteringDependentLogic.ScatteredLogic. commitSingleEntry(CacheEntry entry, FlagAffectedCommand command, InvocationContext ctx, Flag trackFlag, boolean l1Invalidation)
ClusteringDependentLogic.Commit
ClusteringDependentLogic.AbstractClusteringDependentLogic. commitType(FlagAffectedCommand command, InvocationContext ctx, int segment, boolean removed)
ClusteringDependentLogic.Commit
ClusteringDependentLogic. commitType(FlagAffectedCommand command, InvocationContext ctx, int segment, boolean removed)
Determines what type of commit this is.ClusteringDependentLogic.Commit
ClusteringDependentLogic.InvalidationLogic. commitType(FlagAffectedCommand command, InvocationContext ctx, int segment, boolean removed)
ClusteringDependentLogic.Commit
ClusteringDependentLogic.LocalLogic. commitType(FlagAffectedCommand command, InvocationContext ctx, int segment, boolean removed)
ClusteringDependentLogic.Commit
ClusteringDependentLogic.ReplicationLogic. commitType(FlagAffectedCommand command, InvocationContext ctx, int segment, boolean removed)
protected abstract Object
AbstractLockingInterceptor. handleReadManyCommand(InvocationContext ctx, FlagAffectedCommand command, Collection<?> keys)
protected Object
AbstractTxLockingInterceptor. handleReadManyCommand(InvocationContext ctx, FlagAffectedCommand command, Collection<?> keys)
protected Object
NonTransactionalLockingInterceptor. handleReadManyCommand(InvocationContext ctx, FlagAffectedCommand command, Collection<?> keys)
protected Object
OptimisticLockingInterceptor. handleReadManyCommand(InvocationContext ctx, FlagAffectedCommand command, Collection<?> keys)
protected Object
PessimisticLockingInterceptor. handleReadManyCommand(InvocationContext ctx, FlagAffectedCommand command, Collection<?> keys)
protected abstract <K> Object
AbstractLockingInterceptor. handleWriteManyCommand(InvocationContext ctx, WriteCommand command, Collection<K> keys, boolean forwarded)
protected <K> Object
NonTransactionalLockingInterceptor. handleWriteManyCommand(InvocationContext ctx, WriteCommand command, Collection<K> keys, boolean forwarded)
protected <K> Object
OptimisticLockingInterceptor. handleWriteManyCommand(InvocationContext ctx, WriteCommand command, Collection<K> keys, boolean forwarded)
protected <K> Object
PessimisticLockingInterceptor. handleWriteManyCommand(InvocationContext ctx, WriteCommand command, Collection<K> keys, boolean forwarded)
protected KeyAwareLockPromise
AbstractLockingInterceptor. lockAndRecord(InvocationContext context, Object key, long timeout)
Object
AbstractLockingInterceptor. visitClearCommand(InvocationContext ctx, ClearCommand command)
Object
AbstractLockingInterceptor. visitComputeCommand(InvocationContext ctx, ComputeCommand command)
Object
AbstractLockingInterceptor. visitComputeIfAbsentCommand(InvocationContext ctx, ComputeIfAbsentCommand command)
protected abstract Object
AbstractLockingInterceptor. visitDataReadCommand(InvocationContext ctx, DataCommand command)
protected Object
NonTransactionalLockingInterceptor. visitDataReadCommand(InvocationContext ctx, DataCommand command)
protected Object
OptimisticLockingInterceptor. visitDataReadCommand(InvocationContext ctx, DataCommand command)
protected Object
PessimisticLockingInterceptor. visitDataReadCommand(InvocationContext ctx, DataCommand command)
protected abstract Object
AbstractLockingInterceptor. visitDataWriteCommand(InvocationContext ctx, DataWriteCommand command)
protected Object
NonTransactionalLockingInterceptor. visitDataWriteCommand(InvocationContext ctx, DataWriteCommand command)
protected Object
OptimisticLockingInterceptor. visitDataWriteCommand(InvocationContext ctx, DataWriteCommand command)
protected Object
PessimisticLockingInterceptor. visitDataWriteCommand(InvocationContext ctx, DataWriteCommand command)
Object
AbstractLockingInterceptor. visitGetAllCommand(InvocationContext ctx, GetAllCommand command)
Object
AbstractLockingInterceptor. visitGetCacheEntryCommand(InvocationContext ctx, GetCacheEntryCommand command)
Object
AbstractLockingInterceptor. visitGetKeyValueCommand(InvocationContext ctx, GetKeyValueCommand command)
Object
AbstractLockingInterceptor. visitInvalidateCommand(InvocationContext ctx, InvalidateCommand command)
Object
AbstractLockingInterceptor. visitInvalidateL1Command(InvocationContext ctx, InvalidateL1Command command)
Object
AbstractLockingInterceptor. visitPutKeyValueCommand(InvocationContext ctx, PutKeyValueCommand command)
Object
AbstractLockingInterceptor. visitPutMapCommand(InvocationContext ctx, PutMapCommand command)
Object
AbstractLockingInterceptor. visitReadOnlyKeyCommand(InvocationContext ctx, ReadOnlyKeyCommand command)
Object
AbstractLockingInterceptor. visitReadOnlyManyCommand(InvocationContext ctx, ReadOnlyManyCommand command)
Object
AbstractLockingInterceptor. visitReadWriteKeyCommand(InvocationContext ctx, ReadWriteKeyCommand command)
Object
AbstractLockingInterceptor. visitReadWriteKeyValueCommand(InvocationContext ctx, ReadWriteKeyValueCommand command)
Object
AbstractLockingInterceptor. visitReadWriteManyCommand(InvocationContext ctx, ReadWriteManyCommand command)
Object
AbstractLockingInterceptor. visitReadWriteManyEntriesCommand(InvocationContext ctx, ReadWriteManyEntriesCommand command)
Object
AbstractLockingInterceptor. visitRemoveCommand(InvocationContext ctx, RemoveCommand command)
Object
AbstractLockingInterceptor. visitReplaceCommand(InvocationContext ctx, ReplaceCommand command)
Object
AbstractLockingInterceptor. visitWriteOnlyKeyCommand(InvocationContext ctx, WriteOnlyKeyCommand command)
Object
AbstractLockingInterceptor. visitWriteOnlyKeyValueCommand(InvocationContext ctx, WriteOnlyKeyValueCommand command)
Object
AbstractLockingInterceptor. visitWriteOnlyManyCommand(InvocationContext ctx, WriteOnlyManyCommand command)
Object
AbstractLockingInterceptor. visitWriteOnlyManyEntriesCommand(InvocationContext ctx, WriteOnlyManyEntriesCommand command)
-
Uses of InvocationContext in org.infinispan.interceptors.totalorder
Methods in org.infinispan.interceptors.totalorder with parameters of type InvocationContext Modifier and Type Method Description protected void
TotalOrderVersionedEntryWrappingInterceptor. commitContextEntry(CacheEntry entry, InvocationContext ctx, FlagAffectedCommand command, Flag stateTransferFlag, boolean l1Invalidation)
protected Object
TotalOrderStateTransferInterceptor. handleDefault(InvocationContext ctx, VisitableCommand command)
-
Uses of InvocationContext in org.infinispan.interceptors.xsite
-
Uses of InvocationContext in org.infinispan.notifications.cachelistener
Methods in org.infinispan.notifications.cachelistener with parameters of type InvocationContext Modifier and Type Method Description static void
NotifyHelper. entryCommitted(CacheNotifier notifier, org.infinispan.functional.impl.FunctionalNotifier functionalNotifier, boolean created, boolean removed, boolean expired, CacheEntry entry, InvocationContext ctx, FlagAffectedCommand command, Object previousValue, Metadata previousMetadata)
void
CacheNotifier. notifyCacheEntriesEvicted(Collection<InternalCacheEntry<? extends K,? extends V>> entries, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntriesEvictedEvent
event.void
CacheNotifierImpl. notifyCacheEntriesEvicted(Collection<InternalCacheEntry<? extends K,? extends V>> entries, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryActivated(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryActivatedEvent
event.void
CacheNotifierImpl. notifyCacheEntryActivated(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryCreated(K key, V value, Metadata metadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryCreatedEvent
event.void
CacheNotifierImpl. notifyCacheEntryCreated(K key, V value, Metadata metadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryExpired(K key, V value, Metadata metadata, InvocationContext ctx)
Notifies all registered listeners of a CacheEntryExpired event.void
CacheNotifierImpl. notifyCacheEntryExpired(K key, V value, Metadata metadata, InvocationContext ctx)
void
CacheNotifier. notifyCacheEntryInvalidated(K key, V value, Metadata metadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryInvalidatedEvent
event.void
CacheNotifierImpl. notifyCacheEntryInvalidated(K key, V value, Metadata metadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryLoaded(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryLoadedEvent
event.void
CacheNotifierImpl. notifyCacheEntryLoaded(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryModified(K key, V value, Metadata metadata, V previousValue, Metadata previousMetadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryModifiedEvent
event.void
CacheNotifierImpl. notifyCacheEntryModified(K key, V value, Metadata metadata, V previousValue, Metadata previousMetadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryPassivated(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryPassivatedEvent
event.void
CacheNotifierImpl. notifyCacheEntryPassivated(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryRemoved(K key, V previousValue, Metadata previousMetadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryRemovedEvent
event.void
CacheNotifierImpl. notifyCacheEntryRemoved(K key, V previousValue, Metadata previousMetadata, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyCacheEntryVisited(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
Notifies all registered listeners of aCacheEntryVisitedEvent
event.void
CacheNotifierImpl. notifyCacheEntryVisited(K key, V value, boolean pre, InvocationContext ctx, FlagAffectedCommand command)
void
CacheNotifier. notifyTransactionCompleted(GlobalTransaction transaction, boolean successful, InvocationContext ctx)
Notifies all registered listeners of a transaction completion event.void
CacheNotifierImpl. notifyTransactionCompleted(GlobalTransaction transaction, boolean successful, InvocationContext ctx)
-
Uses of InvocationContext in org.infinispan.persistence
Methods in org.infinispan.persistence with parameters of type InvocationContext Modifier and Type Method Description static <K,V>
MarshalledEntry<K,V>PersistenceUtil. loadAndCheckExpiration(PersistenceManager persistenceManager, Object key, InvocationContext context, TimeService timeService)
Deprecated.since 9.4 This method references PersistenceManager, which isn't a public classstatic <K,V>
InternalCacheEntry<K,V>PersistenceUtil. loadAndComputeInDataContainer(DataContainer<K,V> dataContainer, int segment, PersistenceManager persistenceManager, K key, InvocationContext ctx, TimeService timeService, DataContainer.ComputeAction<K,V> action)
Deprecated.since 9.4 This method references PersistenceManager, which isn't a public classstatic <K,V>
InternalCacheEntry<K,V>PersistenceUtil. loadAndStoreInDataContainer(DataContainer<K,V> dataContainer, int segment, PersistenceManager persistenceManager, K key, InvocationContext ctx, TimeService timeService, AtomicReference<Boolean> isLoaded)
Deprecated.since 9.4 This method references PersistenceManager, which isn't a public classstatic <K,V>
InternalCacheEntry<K,V>PersistenceUtil. loadAndStoreInDataContainer(DataContainer<K,V> dataContainer, PersistenceManager persistenceManager, K key, InvocationContext ctx, TimeService timeService, AtomicReference<Boolean> isLoaded)
Deprecated.since 9.4 This method references PersistenceManager, which isn't a public class -
Uses of InvocationContext in org.infinispan.persistence.internal
Methods in org.infinispan.persistence.internal with parameters of type InvocationContext Modifier and Type Method Description static <K,V>
MarshalledEntry<K,V>PersistenceUtil. loadAndCheckExpiration(PersistenceManager persistenceManager, Object key, int segment, InvocationContext context)
static <K,V>
InternalCacheEntry<K,V>PersistenceUtil. loadAndComputeInDataContainer(DataContainer<K,V> dataContainer, int segment, PersistenceManager persistenceManager, K key, InvocationContext ctx, TimeService timeService, DataContainer.ComputeAction<K,V> action)
static <K,V>
InternalCacheEntry<K,V>PersistenceUtil. loadAndStoreInDataContainer(DataContainer<K,V> dataContainer, int segment, PersistenceManager persistenceManager, K key, InvocationContext ctx, TimeService timeService, AtomicReference<Boolean> isLoaded)
static <K,V>
InternalCacheEntry<K,V>PersistenceUtil. loadAndStoreInDataContainer(DataContainer<K,V> dataContainer, PersistenceManager persistenceManager, K key, InvocationContext ctx, TimeService timeService, AtomicReference<Boolean> isLoaded)
-
Uses of InvocationContext in org.infinispan.query.backend
-
Uses of InvocationContext in org.infinispan.statetransfer
-
Uses of InvocationContext in org.infinispan.stats.topK
Methods in org.infinispan.stats.topK with parameters of type InvocationContext Modifier and Type Method Description Object
CacheUsageInterceptor. visitGetAllCommand(InvocationContext ctx, GetAllCommand command)
Object
CacheUsageInterceptor. visitGetKeyValueCommand(InvocationContext ctx, GetKeyValueCommand command)
Object
CacheUsageInterceptor. visitPutKeyValueCommand(InvocationContext ctx, PutKeyValueCommand command)
-
Uses of InvocationContext in org.infinispan.stats.wrappers
-
Uses of InvocationContext in org.infinispan.util.concurrent.locks
Methods in org.infinispan.util.concurrent.locks with parameters of type InvocationContext Modifier and Type Method Description void
LockManager. unlockAll(InvocationContext context)
Same asunlockAll(context.getLockedKeys(), context.getKeyLockOwner();
.
-