Package | Description |
---|---|
org.infinispan.cache.impl | |
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.tx |
Commands that represent transactional lifecycle transitions.
|
org.infinispan.commands.write |
Commands that alter the state of the cache.
|
org.infinispan.container.impl |
Data containers which store cache entries.
|
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.context.impl |
This package contains different context implementations, selected dynamically based on the type of invocation.
|
org.infinispan.functional.impl | |
org.infinispan.interceptors |
Infinispan is designed around a set of interceptors around a data container.
|
org.infinispan.interceptors.distribution |
Interceptors dealing with command replication in distributed/replicated mode.
|
org.infinispan.interceptors.impl |
Basic interceptors
|
org.infinispan.interceptors.locking |
Interceptors dealing with locking.
|
org.infinispan.interceptors.xsite |
Interceptors dealing with cross-site replication.
|
org.infinispan.notifications.cachelistener |
Cache -specific notifications and eventing. |
org.infinispan.partitionhandling.impl | |
org.infinispan.persistence |
Persistence API.
|
org.infinispan.persistence.internal | |
org.infinispan.persistence.manager |
Implementations of the
PersistenceManager interface, which define the logic
of how infinispan interacts with external stores. |
org.infinispan.persistence.support | |
org.infinispan.persistence.util | |
org.infinispan.reactive.publisher.impl | |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stream.impl | |
org.infinispan.util.concurrent.locks |
Lock and synchronization related classes, tools and utilities.
|
org.infinispan.util.concurrent.locks.impl |
Modifier and Type | Method and Description |
---|---|
InvocationContext |
ContextBuilder.create(int keyCount)
Creates a new
InvocationContext . |
InvocationContext |
InvocationHelper.createInvocationContextWithImplicitTransaction(int keyCount,
boolean forceCreateTransaction)
Creates an invocation context with an implicit transaction if it is required.
|
protected InvocationContext |
DecoratedCache.readContext(int size) |
protected InvocationContext |
DecoratedCache.writeContext(int size) |
Modifier and Type | Method and Description |
---|---|
Map<K,CacheEntry<K,V>> |
CacheImpl.getAllCacheEntries(Set<?> keys,
long explicitFlags,
InvocationContext ctx) |
<T> T |
InvocationHelper.invoke(InvocationContext context,
VisitableCommand command)
Invokes the
command using context . |
<T> CompletableFuture<T> |
InvocationHelper.invokeAsync(InvocationContext context,
VisitableCommand command)
|
Modifier and Type | Method and Description |
---|---|
Object |
LockControlCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
Object |
EntrySetCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
GetAllCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
GetCacheEntryCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
GetKeyValueCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
KeySetCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
SizeCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Modifier and Type | Method and Description |
---|---|
Object |
GetKeysInGroupCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Modifier and Type | Method and Description |
---|---|
Object |
CommitCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
PrepareCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
RollbackCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
<K,V> InternalCacheValue<V> |
InternalEntryFactory.getValueFromCtx(K key,
InvocationContext ctx)
Retrieve an
InternalCacheValue from the provided InvocationContext if an InternalCacheEntry
exists, otherwise create InternalCacheEntry from the context's CacheEntry and return its value. |
<K,V> InternalCacheValue<V> |
InternalEntryFactoryImpl.getValueFromCtx(K key,
InvocationContext ctx) |
void |
EntryFactory.wrapEntryForExpired(InvocationContext ctx,
Object key,
int segment)
Insert an entry that exists in the data container into the context, even if it is expired
Doesn't do anything if the key was already wrapped
|
void |
EntryFactoryImpl.wrapEntryForExpired(InvocationContext ctx,
Object key,
int segment) |
CompletionStage<Void> |
EntryFactory.wrapEntryForReading(InvocationContext ctx,
Object key,
int segment,
boolean isOwner,
boolean hasLock)
Wraps an entry for reading.
|
CompletionStage<Void> |
EntryFactoryImpl.wrapEntryForReading(InvocationContext ctx,
Object key,
int segment,
boolean isOwner,
boolean hasLock) |
CompletionStage<Void> |
EntryFactory.wrapEntryForWriting(InvocationContext ctx,
Object key,
int segment,
boolean isOwner,
boolean isRead)
Insert an entry that exists in the data container into the context.
|
CompletionStage<Void> |
EntryFactoryImpl.wrapEntryForWriting(InvocationContext ctx,
Object key,
int segment,
boolean isOwner,
boolean isRead) |
void |
EntryFactory.wrapExternalEntry(InvocationContext ctx,
Object key,
CacheEntry externalEntry,
boolean isRead,
boolean isWrite)
Insert an external entry (e.g.
|
void |
EntryFactoryImpl.wrapExternalEntry(InvocationContext ctx,
Object key,
CacheEntry externalEntry,
boolean isRead,
boolean isWrite) |
Modifier and Type | Interface and Description |
---|---|
interface |
TxInvocationContext<T extends AbstractCacheTransaction>
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractInvocationContext
Common features of transaction and invocation contexts
|
class |
AbstractTxInvocationContext<T extends AbstractCacheTransaction>
Support class for
TxInvocationContext . |
class |
ClearInvocationContext
Implementation of
InvocationContext used by the ClearCommand . |
class |
ImmutableContext
This context is a non-context for operations such as eviction which are not related
to the method invocation which caused them.
|
class |
LocalTxInvocationContext
Invocation context to be used for locally originated transactions.
|
class |
NonTxInvocationContext
Context to be used for non transactional calls, both remote and local.
|
class |
RemoteTxInvocationContext
Context to be used for transaction that originated remotely.
|
class |
SingleKeyNonTxInvocationContext |
Modifier and Type | Method and Description |
---|---|
InvocationContext |
AbstractInvocationContext.clone() |
InvocationContext |
ImmutableContext.clone() |
InvocationContext |
SingleKeyNonTxInvocationContext.clone() |
InvocationContext |
AbstractInvocationContextFactory.createClearNonTxInvocationContext() |
InvocationContext |
NonTransactionalInvocationContextFactory.createInvocationContext(boolean isWrite,
int keyCount) |
InvocationContext |
TransactionalInvocationContextFactory.createInvocationContext(boolean isWrite,
int keyCount) |
InvocationContext |
NonTransactionalInvocationContextFactory.createInvocationContext(Transaction tx,
boolean implicitTransaction) |
InvocationContext |
TransactionalInvocationContextFactory.createInvocationContext(Transaction tx,
boolean implicitTransaction) |
InvocationContext |
AbstractInvocationContextFactory.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand,
Address origin) |
InvocationContext |
NonTransactionalInvocationContextFactory.createSingleKeyNonTxInvocationContext() |
InvocationContext |
TransactionalInvocationContextFactory.createSingleKeyNonTxInvocationContext() |
Modifier and Type | Method and Description |
---|---|
static Flag |
FlagBitSets.extractStateTransferFlag(InvocationContext ctx,
FlagAffectedCommand command) |
Modifier and Type | Method and Description |
---|---|
static Object |
StatsEnvelope.unpack(InvocationContext ctx,
VisitableCommand command,
Object o) |
static Object |
StatsEnvelope.unpackCollection(InvocationContext ctx,
VisitableCommand command,
Object o) |
static Object |
StatsEnvelope.unpackStream(InvocationContext ctx,
VisitableCommand command,
Object o) |
Modifier and Type | Method and Description |
---|---|
void |
InvocationSuccessAction.accept(InvocationContext rCtx,
C rCommand,
Object rv)
Process the result from a successful invocation stage and possibly throw an exception.
|
void |
InvocationFinallyAction.accept(InvocationContext rCtx,
C rCommand,
Object rv,
Throwable throwable)
Process the result or the exception from an invocation stage and possibly throw an exception.
|
abstract <C extends VisitableCommand> |
InvocationStage.addCallback(InvocationContext ctx,
C command,
InvocationCallback<C> function)
After the current stage completes, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.addCallback(InvocationContext ctx,
C command,
InvocationCallback<C> function) |
Object |
ExceptionSyncInvocationStage.addCallback(InvocationContext ctx,
VisitableCommand command,
InvocationCallback function) |
<C extends VisitableCommand> |
InvocationStage.andExceptionally(InvocationContext ctx,
C command,
InvocationExceptionFunction<C> function)
After the current stage completes exceptionally, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.andExceptionally(InvocationContext ctx,
C command,
InvocationExceptionFunction<C> function) |
Object |
ExceptionSyncInvocationStage.andExceptionally(InvocationContext ctx,
VisitableCommand command,
InvocationExceptionFunction function) |
<C extends VisitableCommand> |
InvocationStage.andExceptionallyMakeStage(InvocationContext ctx,
C command,
InvocationExceptionFunction<C> function)
After the current stage completes exceptionally, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.andExceptionallyMakeStage(InvocationContext ctx,
C command,
InvocationExceptionFunction<C> function) |
<C extends VisitableCommand> |
InvocationStage.andFinally(InvocationContext ctx,
C command,
InvocationFinallyAction<C> action)
After the current stage completes, invoke
action . |
<C extends VisitableCommand> |
SyncInvocationStage.andFinally(InvocationContext ctx,
C command,
InvocationFinallyAction<C> action) |
Object |
ExceptionSyncInvocationStage.andFinally(InvocationContext ctx,
VisitableCommand command,
InvocationFinallyAction action) |
<C extends VisitableCommand> |
InvocationStage.andFinallyMakeStage(InvocationContext ctx,
C command,
InvocationFinallyAction<C> action)
After the current stage completes, invoke
action . |
<C extends VisitableCommand> |
SyncInvocationStage.andFinallyMakeStage(InvocationContext ctx,
C command,
InvocationFinallyAction<C> action) |
<C extends VisitableCommand> |
InvocationStage.andHandle(InvocationContext ctx,
C command,
InvocationFinallyFunction<C> function)
After the current stage completes, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.andHandle(InvocationContext ctx,
C command,
InvocationFinallyFunction<C> function) |
Object |
ExceptionSyncInvocationStage.andHandle(InvocationContext ctx,
VisitableCommand command,
InvocationFinallyFunction function) |
<C extends VisitableCommand> |
InvocationStage.andHandleMakeStage(InvocationContext ctx,
C command,
InvocationFinallyFunction<C> function)
After the current stage completes, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.andHandleMakeStage(InvocationContext ctx,
C command,
InvocationFinallyFunction<C> function) |
Object |
InvocationSuccessFunction.apply(InvocationContext rCtx,
C rCommand,
Object rv)
Process the result from a successful invocation stage and either return a simple value,
return a new
InvocationStage , or throw an exception. |
Object |
InvocationCallback.apply(InvocationContext rCtx,
C rCommand,
Object rv,
Throwable throwable)
Process the result or the exception from an invocation stage and either return a simple value,
return a new
InvocationStage , or throw an exception. |
default Object |
InvocationExceptionFunction.apply(InvocationContext rCtx,
C rCommand,
Object rv,
Throwable throwable) |
default Object |
InvocationFinallyAction.apply(InvocationContext rCtx,
C rCommand,
Object rv,
Throwable throwable) |
default Object |
InvocationSuccessAction.apply(InvocationContext rCtx,
C rCommand,
Object rv,
Throwable throwable) |
default Object |
InvocationSuccessFunction.apply(InvocationContext rCtx,
C rCommand,
Object rv,
Throwable throwable) |
Object |
InvocationExceptionFunction.apply(InvocationContext rCtx,
C rCommand,
Throwable throwable)
Process the result from a successful invocation stage and either return a simple value,
return a new
InvocationStage , or throw an exception. |
Object |
BaseAsyncInterceptor.asyncInvokeNext(InvocationContext ctx,
VisitableCommand command,
Collection<? extends CompletionStage<?>> delays)
Suspend invocation until all
delays complete, then if successful invoke the next interceptor. |
Object |
BaseAsyncInterceptor.asyncInvokeNext(InvocationContext ctx,
VisitableCommand command,
CompletionStage<?> delay)
Suspend the invocation until
delay completes, then if successful invoke the next interceptor. |
Object |
BaseAsyncInterceptor.asyncInvokeNext(InvocationContext ctx,
VisitableCommand command,
InvocationStage invocationStage)
Suspend the invocation until
invocationStage 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) |
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.
|
<C extends VisitableCommand> |
BaseAsyncInterceptor.invokeNextAndExceptionally(InvocationContext ctx,
C command,
InvocationExceptionFunction<C> function)
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished with an exception. |
<C extends VisitableCommand> |
BaseAsyncInterceptor.invokeNextAndFinally(InvocationContext ctx,
C command,
InvocationFinallyAction<C> action)
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished, with or without an exception. |
<C extends VisitableCommand> |
BaseAsyncInterceptor.invokeNextAndHandle(InvocationContext ctx,
C command,
InvocationFinallyFunction<C> function)
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished, with or without an exception. |
<C extends VisitableCommand> |
BaseAsyncInterceptor.invokeNextThenAccept(InvocationContext ctx,
C command,
InvocationSuccessAction<C> action)
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished successfully. |
<C extends VisitableCommand> |
BaseAsyncInterceptor.invokeNextThenApply(InvocationContext ctx,
C command,
InvocationSuccessFunction<C> function)
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished successfully. |
<C extends VisitableCommand> |
InvocationStage.thenAccept(InvocationContext ctx,
C command,
InvocationSuccessAction<C> action)
After the current stage completes successfully, invoke
action . |
<C extends VisitableCommand> |
SyncInvocationStage.thenAccept(InvocationContext ctx,
C command,
InvocationSuccessAction<C> action) |
Object |
ExceptionSyncInvocationStage.thenAccept(InvocationContext ctx,
VisitableCommand command,
InvocationSuccessAction function) |
<C extends VisitableCommand> |
InvocationStage.thenAcceptMakeStage(InvocationContext ctx,
C command,
InvocationSuccessAction<C> action)
After the current stage completes successfully, invoke
action . |
<C extends VisitableCommand> |
SyncInvocationStage.thenAcceptMakeStage(InvocationContext ctx,
C command,
InvocationSuccessAction<C> action) |
<C extends VisitableCommand> |
InvocationStage.thenApply(InvocationContext ctx,
C command,
InvocationSuccessFunction<C> function)
After the current stage completes successfully, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.thenApply(InvocationContext ctx,
C command,
InvocationSuccessFunction<C> function) |
Object |
ExceptionSyncInvocationStage.thenApply(InvocationContext ctx,
VisitableCommand command,
InvocationSuccessFunction function) |
<C extends VisitableCommand> |
InvocationStage.thenApplyMakeStage(InvocationContext ctx,
C command,
InvocationSuccessFunction<C> function)
After the current stage completes successfully, invoke
function and return its result. |
<C extends VisitableCommand> |
SyncInvocationStage.thenApplyMakeStage(InvocationContext ctx,
C command,
InvocationSuccessFunction<C> function)
After the current stage completes successfully, invoke
function and return its result. |
Object |
ExceptionSyncInvocationStage.thenReturn(InvocationContext ctx,
VisitableCommand command,
Object returnValue) |
Object |
InvocationStage.thenReturn(InvocationContext ctx,
VisitableCommand command,
Object returnValue)
Overrides the return value of this
InvocationStage if it is completed successfully. |
Object |
SyncInvocationStage.thenReturn(InvocationContext ctx,
VisitableCommand command,
Object returnValue) |
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) |
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) |
Constructor and Description |
---|
QueueAsyncInvocationStage(InvocationContext ctx,
VisitableCommand command,
CompletableFuture<?> valueFuture,
InvocationCallback function) |
Modifier and Type | Method and Description |
---|---|
protected ClusteringDependentLogic.Commit |
ClusteringDependentLogic.AbstractClusteringDependentLogic.clusterCommitType(FlagAffectedCommand command,
InvocationContext ctx,
int segment,
boolean removed) |
CompletionStage<Void> |
ClusteringDependentLogic.commitEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation)
Commits the entry to the data container.
|
CompletionStage<Void> |
ClusteringDependentLogic.AbstractClusteringDependentLogic.commitEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
CompletionStage<Void> |
OrderedClusteringDependentLogic.commitEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected abstract CompletionStage<Void> |
ClusteringDependentLogic.AbstractClusteringDependentLogic.commitSingleEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected CompletionStage<Void> |
ClusteringDependentLogic.LocalLogic.commitSingleEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected CompletionStage<Void> |
ClusteringDependentLogic.InvalidationLogic.commitSingleEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected CompletionStage<Void> |
ClusteringDependentLogic.ReplicationLogic.commitSingleEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected CompletionStage<Void> |
ClusteringDependentLogic.DistributionLogic.commitSingleEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected CompletableFuture<Void> |
ClusteringDependentLogic.ScatteredLogic.commitSingleEntry(CacheEntry entry,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
ClusteringDependentLogic.Commit |
ClusteringDependentLogic.commitType(FlagAffectedCommand command,
InvocationContext ctx,
int segment,
boolean removed)
Determines what type of commit this is.
|
ClusteringDependentLogic.Commit |
ClusteringDependentLogic.AbstractClusteringDependentLogic.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.InvalidationLogic.commitType(FlagAffectedCommand command,
InvocationContext ctx,
int segment,
boolean removed) |
ClusteringDependentLogic.Commit |
ClusteringDependentLogic.ReplicationLogic.commitType(FlagAffectedCommand command,
InvocationContext ctx,
int segment,
boolean removed) |
ClusteringDependentLogic.Commit |
OrderedClusteringDependentLogic.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 InvocationStage |
AbstractLockingInterceptor.lockAndRecord(InvocationContext context,
VisitableCommand command,
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) |
Modifier and Type | Method and Description |
---|---|
static CompletionStage<Void> |
NotifyHelper.entryCommitted(CacheNotifier notifier,
FunctionalNotifier functionalNotifier,
boolean created,
boolean removed,
boolean expired,
CacheEntry entry,
InvocationContext ctx,
FlagAffectedCommand command,
Object previousValue,
Metadata previousMetadata,
EvictionManager evictionManager) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntriesEvicted(Collection<Map.Entry<K,V>> entries,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntriesEvictedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntriesEvicted(Collection<Map.Entry<K,V>> entries,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryActivated(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryActivatedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryActivated(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryCreated(K key,
V value,
Metadata metadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryCreatedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryCreated(K key,
V value,
Metadata metadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryExpired(K key,
V value,
Metadata metadata,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryExpired event.
|
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryExpired(K key,
V value,
Metadata metadata,
InvocationContext ctx) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryInvalidated(K key,
V value,
Metadata metadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryInvalidatedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryInvalidated(K key,
V value,
Metadata metadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryLoaded(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryLoadedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryLoaded(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryModified(K key,
V value,
Metadata metadata,
V previousValue,
Metadata previousMetadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryModifiedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryModified(K key,
V value,
Metadata metadata,
V previousValue,
Metadata previousMetadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryPassivated(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryPassivatedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryPassivated(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryRemoved(K key,
V previousValue,
Metadata previousMetadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryRemovedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryRemoved(K key,
V previousValue,
Metadata previousMetadata,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyCacheEntryVisited(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command)
Notifies all registered listeners of a
CacheEntryVisitedEvent
event. |
CompletionStage<Void> |
CacheNotifierImpl.notifyCacheEntryVisited(K key,
V value,
boolean pre,
InvocationContext ctx,
FlagAffectedCommand command) |
CompletionStage<Void> |
CacheNotifier.notifyTransactionCompleted(GlobalTransaction transaction,
boolean successful,
InvocationContext ctx)
Notifies all registered listeners of a transaction completion event.
|
CompletionStage<Void> |
CacheNotifierImpl.notifyTransactionCompleted(GlobalTransaction transaction,
boolean successful,
InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
static <K,V> MarshallableEntry<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 class
|
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)
Deprecated.
since 9.4 This method references PersistenceManager, which isn't a public class
|
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)
Deprecated.
since 9.4 This method references PersistenceManager, which isn't a public class
|
static <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
|
Modifier and Type | Method and Description |
---|---|
static <K,V> MarshallableEntry<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) |
Modifier and Type | Method and Description |
---|---|
CompletionStage<Long> |
PersistenceManager.writeMapCommand(PutMapCommand putMapCommand,
InvocationContext ctx,
BiPredicate<? super PutMapCommand,Object> commandKeyPredicate)
Writes the values modified from a put map command to the stores.
|
CompletionStage<Long> |
PersistenceManagerImpl.writeMapCommand(PutMapCommand putMapCommand,
InvocationContext ctx,
BiPredicate<? super PutMapCommand,Object> commandKeyPredicate) |
CompletionStage<Long> |
PersistenceManagerStub.writeMapCommand(PutMapCommand putMapCommand,
InvocationContext ctx,
BiPredicate<? super PutMapCommand,Object> commandKeyPredicate) |
Modifier and Type | Method and Description |
---|---|
CompletionStage<Long> |
DelegatingPersistenceManager.writeMapCommand(PutMapCommand putMapCommand,
InvocationContext ctx,
BiPredicate<? super PutMapCommand,Object> commandKeyPredicate) |
Modifier and Type | Method and Description |
---|---|
CompletionStage<InternalCacheEntry<K,V>> |
EntryLoader.loadAndStoreInDataContainer(InvocationContext ctx,
Object key,
int segment,
FlagAffectedCommand cmd)
Load and store the entry if present in the data container, returning the entry in the CompletionStage
|
Modifier and Type | Method and Description |
---|---|
<R> SegmentCompletionPublisher<R> |
ClusterPublisherManager.entryPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends org.reactivestreams.Publisher<R>> transformer)
Performs the given transformer on data in the cache, resulting in multiple values.
|
<R> SegmentCompletionPublisher<R> |
ClusterPublisherManagerImpl.entryPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends org.reactivestreams.Publisher<R>> transformer) |
<R> SegmentCompletionPublisher<R> |
LocalClusterPublisherManagerImpl.entryPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends org.reactivestreams.Publisher<R>> transformer) |
<R> SegmentCompletionPublisher<R> |
PartitionAwareClusterPublisherManager.entryPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends org.reactivestreams.Publisher<R>> transformer) |
<R> CompletionStage<R> |
ClusterPublisherManager.entryReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer)
Performs the given transformer and finalizer on data in the cache, resulting in a single value.
|
<R> CompletionStage<R> |
ClusterPublisherManagerImpl.entryReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext ctx,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer) |
<R> CompletionStage<R> |
LocalClusterPublisherManagerImpl.entryReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer) |
<R> CompletionStage<R> |
PartitionAwareClusterPublisherManager.entryReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext ctx,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<CacheEntry<K,V>>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer) |
<R> SegmentCompletionPublisher<R> |
ClusterPublisherManager.keyPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<K>,? extends org.reactivestreams.Publisher<R>> transformer)
Same as
ClusterPublisherManager.entryPublisher(IntSet, Set, InvocationContext, boolean, DeliveryGuarantee, int, Function)
except that the source publisher provided to the transformer is made up of keys only. |
<R> SegmentCompletionPublisher<R> |
ClusterPublisherManagerImpl.keyPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<K>,? extends org.reactivestreams.Publisher<R>> transformer) |
<R> SegmentCompletionPublisher<R> |
LocalClusterPublisherManagerImpl.keyPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<K>,? extends org.reactivestreams.Publisher<R>> transformer) |
<R> SegmentCompletionPublisher<R> |
PartitionAwareClusterPublisherManager.keyPublisher(IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
int batchSize,
Function<? super org.reactivestreams.Publisher<K>,? extends org.reactivestreams.Publisher<R>> transformer) |
<R> CompletionStage<R> |
ClusterPublisherManager.keyReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<K>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer)
Same as
ClusterPublisherManager.entryReduction(boolean, IntSet, Set, InvocationContext, boolean, DeliveryGuarantee, Function, Function)
except that the source publisher provided to the transformer is made up of keys only. |
<R> CompletionStage<R> |
ClusterPublisherManagerImpl.keyReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext ctx,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<K>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer) |
<R> CompletionStage<R> |
LocalClusterPublisherManagerImpl.keyReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext invocationContext,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<K>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer) |
<R> CompletionStage<R> |
PartitionAwareClusterPublisherManager.keyReduction(boolean parallelPublisher,
IntSet segments,
Set<K> keysToInclude,
InvocationContext ctx,
boolean includeLoader,
DeliveryGuarantee deliveryGuarantee,
Function<? super org.reactivestreams.Publisher<K>,? extends CompletionStage<R>> transformer,
Function<? super org.reactivestreams.Publisher<R>,? extends CompletionStage<R>> finalizer) |
Modifier and Type | Field and Description |
---|---|
protected InvocationContext |
AbstractCacheStream.invocationContext |
Constructor and Description |
---|
AbstractCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
InvocationContext ctx,
Supplier<CacheStream<Original>> supplier,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super Original,?> toKeyFunction) |
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
InvocationContext ctx,
Supplier<CacheStream<R>> supplier,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super Original,?> toKeyFunction)
Standard constructor requiring all pertinent information to properly utilize a distributed cache stream
|
Modifier and Type | Method and Description |
---|---|
void |
LockManager.unlockAll(InvocationContext context)
Same as
unlockAll(context.getLockedKeys(), context.getKeyLockOwner(); . |
Modifier and Type | Method and Description |
---|---|
void |
DefaultLockManager.unlockAll(InvocationContext context) |
Copyright © 2021 JBoss by Red Hat. All rights reserved.