Package | Description |
---|---|
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.container.entries |
Entries which are stored in data containers.
|
org.infinispan.context.impl |
This package contains different context implementations, selected dynamically based on the type of invocation.
|
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 | |
org.infinispan.interceptors.locking | |
org.infinispan.interceptors.totalorder | |
org.infinispan.interceptors.xsite | |
org.infinispan.iteration.impl |
Provides Infinispan-specific implementation details iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.partitionhandling.impl | |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stats.topK | |
org.infinispan.stats.wrappers | |
org.infinispan.transaction.impl | |
org.infinispan.util |
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and
collections and containers designed to supplement the JDK-provided containers.
|
org.infinispan.util.concurrent.locks |
Lock and synchronization related classes, tools and utilities.
|
org.infinispan.util.concurrent.locks.impl | |
org.infinispan.xsite |
Modifier and Type | Method and Description |
---|---|
Object |
AbstractVisitor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
Visitor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
AbstractVisitor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command) |
Object |
Visitor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command) |
Object |
AbstractVisitor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
Visitor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
AbstractVisitor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Object |
Visitor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Modifier and Type | Method and Description |
---|---|
boolean |
ClusteredRepeatableReadEntry.performWriteSkewCheck(DataContainer container,
PersistenceManager persistenceManager,
TxInvocationContext ctx,
EntryVersion versionSeen,
VersionGenerator versionGenerator,
TimeService timeService) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTxInvocationContext<T extends AbstractCacheTransaction>
Support class for
TxInvocationContext . |
class |
LocalTxInvocationContext
Invocation context to be used for locally originated transactions.
|
class |
RemoteTxInvocationContext
Context to be used for transaction that originated remotely.
|
Modifier and Type | Method and Description |
---|---|
protected void |
CacheWriterInterceptor.commitCommand(TxInvocationContext ctx)
Deprecated.
|
LocalTransaction |
TxInterceptor.enlist(TxInvocationContext ctx)
Deprecated.
|
protected boolean |
EntryWrappingInterceptor.shouldCommitDuringPrepare(PrepareCommand command,
TxInvocationContext ctx)
Deprecated.
total order condition: only commits when it is remote context and the prepare has the flag 1PC set
|
protected void |
CacheWriterInterceptor.store(TxInvocationContext ctx)
Deprecated.
|
Object |
NotificationInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TxInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
VersionedEntryWrappingInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
InvalidationInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
CacheWriterInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
CallInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
EntryWrappingInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TxInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
DeadlockDetectingInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
InvocationContextInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand lcc)
Deprecated.
|
Object |
InvalidationInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
IsMarshallableInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
MarshalledValueInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
CallInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand c)
Deprecated.
|
Object |
NotificationInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
TxInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
DeadlockDetectingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
VersionedEntryWrappingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
InvalidationInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
CacheWriterInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
CallInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
EntryWrappingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
NotificationInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Object |
TxInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Object |
CallInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
protected void |
EntryWrappingInterceptor.wrapEntriesForPrepare(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
BaseRpcInterceptor.shouldInvokeRemoteTxCommand(TxInvocationContext ctx)
Deprecated.
|
protected static boolean |
BaseRpcInterceptor.shouldTotalOrderRollbackBeInvokedRemotely(TxInvocationContext ctx)
Deprecated.
|
protected static void |
BaseRpcInterceptor.totalOrderTxCommit(TxInvocationContext ctx)
Deprecated.
|
protected static void |
BaseRpcInterceptor.totalOrderTxRollback(TxInvocationContext ctx)
Deprecated.
|
protected static void |
BaseRpcInterceptor.transactionRemotelyPrepared(TxInvocationContext ctx)
Deprecated.
|
Object |
PrePostProcessingCommandInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Modifier and Type | Method and Description |
---|---|
protected void |
VersionedDistributionInterceptor.prepareOnAffectedNodes(TxInvocationContext<?> ctx,
PrepareCommand command,
Collection<Address> recipients)
Deprecated.
|
protected void |
TxDistributionInterceptor.prepareOnAffectedNodes(TxInvocationContext<?> ctx,
PrepareCommand command,
Collection<Address> recipients)
Deprecated.
|
Object |
L1TxInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
L1LastChanceInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TxDistributionInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TxDistributionInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
L1TxInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
L1LastChanceInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
TxDistributionInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
TxDistributionInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
EntryVersionsMap |
ClusteringDependentLogic.createNewVersionsAndCheckForWriteSkews(VersionGenerator versionGenerator,
TxInvocationContext context,
VersionedPrepareCommand prepareCommand) |
EntryVersionsMap |
ClusteringDependentLogic.AbstractClusteringDependentLogic.createNewVersionsAndCheckForWriteSkews(VersionGenerator versionGenerator,
TxInvocationContext context,
VersionedPrepareCommand prepareCommand) |
EntryVersionsMap |
ClusteringDependentLogic.LocalLogic.createNewVersionsAndCheckForWriteSkews(VersionGenerator versionGenerator,
TxInvocationContext context,
VersionedPrepareCommand prepareCommand) |
protected Object |
AbstractTxLockingInterceptor.invokeNextAndCommitIf1Pc(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
protected Collection<Object> |
AbstractTxLockingInterceptor.lockAllOrRegisterBackupLock(TxInvocationContext<?> ctx,
Collection<Object> keys,
long lockTimeout)
Deprecated.
|
protected boolean |
AbstractTxLockingInterceptor.lockOrRegisterBackupLock(TxInvocationContext<?> ctx,
Object key,
long lockTimeout)
Deprecated.
The backup (non-primary) owners keep a "backup lock" for each key they received in a lock/prepare command.
|
Object |
AbstractTxLockingInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
PessimisticLockingInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
OptimisticLockingInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
PessimisticLockingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
OptimisticLockingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
AbstractTxLockingInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TotalOrderDistributionInterceptor.prepareOnAffectedNodes(TxInvocationContext<?> ctx,
PrepareCommand command,
Collection<Address> recipients)
Deprecated.
|
protected void |
TotalOrderVersionedDistributionInterceptor.prepareOnAffectedNodes(TxInvocationContext<?> ctx,
PrepareCommand command,
Collection<Address> recipients)
Deprecated.
|
Object |
TotalOrderDistributionInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TotalOrderVersionedEntryWrappingInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TotalOrderInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TotalOrderVersionedDistributionInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command)
Deprecated.
|
Object |
TotalOrderInterceptor.visitLockControlCommand(TxInvocationContext ctx,
LockControlCommand command)
Deprecated.
|
Object |
TotalOrderVersionedEntryWrappingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
TotalOrderStateTransferInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
TotalOrderInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command)
Deprecated.
|
Object |
TotalOrderDistributionInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Object |
TotalOrderInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Object |
TotalOrderVersionedDistributionInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
BaseBackupInterceptor.shouldInvokeRemoteTxCommand(TxInvocationContext ctx) |
Object |
OptimisticBackupInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
PessimisticBackupInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
OptimisticBackupInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
PessimisticBackupInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
OptimisticBackupInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Modifier and Type | Field and Description |
---|---|
protected TxInvocationContext<LocalTransaction> |
TransactionAwareCloseableIterable.ctx |
Constructor and Description |
---|
TransactionAwareCloseableIterable(CloseableIterable<CacheEntry<K,C>> iterable,
KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,?> cache) |
TransactionAwareCloseableIterator(CloseableIterator<CacheEntry<K,V>> realIterator,
KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,V> cache) |
TransactionAwareEntryIterable(EntryIterable<K,V> entryIterable,
KeyValueFilter<? super K,? super V> filter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,V> cache) |
Modifier and Type | Method and Description |
---|---|
protected void |
PartitionHandlingInterceptor.postTxCommandCheck(TxInvocationContext ctx) |
Object |
PartitionHandlingInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
PartitionHandlingInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Modifier and Type | Method and Description |
---|---|
Object |
CacheUsageInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Modifier and Type | Method and Description |
---|---|
Object |
ExtendedStatisticInterceptor.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
ExtendedStatisticInterceptor.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
ExtendedStatisticInterceptor.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Modifier and Type | Method and Description |
---|---|
static EntryVersionsMap |
WriteSkewHelper.performTotalOrderWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand prepareCommand,
DataContainer dataContainer,
PersistenceManager persistenceManager,
VersionGenerator versionGenerator,
TxInvocationContext context,
WriteSkewHelper.KeySpecificLogic ksl,
TimeService timeService) |
static EntryVersionsMap |
WriteSkewHelper.performWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand prepareCommand,
DataContainer dataContainer,
PersistenceManager persistenceManager,
VersionGenerator versionGenerator,
TxInvocationContext context,
WriteSkewHelper.KeySpecificLogic ksl,
TimeService timeService) |
Modifier and Type | Method and Description |
---|---|
static Collection<Object> |
DeltaCompositeKeyUtil.getAffectedKeysFromContext(TxInvocationContext context) |
Modifier and Type | Method and Description |
---|---|
TxInvocationContext<?> |
TransactionalRemoteLockCommand.createContext()
It creates the transaction context.
|
Modifier and Type | Method and Description |
---|---|
long |
PendingLockManager.awaitPendingTransactionsForAllKeys(TxInvocationContext<?> ctx,
Collection<Object> keys,
long time,
TimeUnit unit)
It waits for any transaction with older topology id to complete that may have the lock for any key in
keys
acquired. |
long |
PendingLockManager.awaitPendingTransactionsForKey(TxInvocationContext<?> ctx,
Object key,
long time,
TimeUnit unit)
It waits for any transaction with older topology id to complete that may have the lock for
key acquired. |
PendingLockPromise |
PendingLockManager.checkPendingTransactionsForKey(TxInvocationContext<?> ctx,
Object key,
long time,
TimeUnit unit)
Same as
PendingLockManager.awaitPendingTransactionsForKey(TxInvocationContext, Object, long, TimeUnit) but non-blocking. |
PendingLockPromise |
PendingLockManager.checkPendingTransactionsForKeys(TxInvocationContext<?> ctx,
Collection<Object> keys,
long time,
TimeUnit unit)
Same as
PendingLockManager.awaitPendingTransactionsForAllKeys(TxInvocationContext, Collection, long, TimeUnit) but
non-blocking. |
Modifier and Type | Method and Description |
---|---|
Object |
BackupSenderImpl.CustomBackupPolicyInvoker.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
BaseBackupReceiver.BackupCacheUpdater.visitCommitCommand(TxInvocationContext ctx,
CommitCommand command) |
Object |
BackupSenderImpl.CustomBackupPolicyInvoker.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
BaseBackupReceiver.BackupCacheUpdater.visitPrepareCommand(TxInvocationContext ctx,
PrepareCommand command) |
Object |
BackupSenderImpl.CustomBackupPolicyInvoker.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Object |
BaseBackupReceiver.BackupCacheUpdater.visitRollbackCommand(TxInvocationContext ctx,
RollbackCommand command) |
Copyright © 2024 JBoss, a division of Red Hat. All rights reserved.