Package | Description |
---|---|
org.hibernate.cache.infinispan.util | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.control |
Commands that control and coordinate certain cache operations, such as rehashing, state transfer and locking.
|
org.infinispan.commands.read |
Commands that read data from the cache.
|
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.container |
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.distribution |
Classes relating to the distributed cache mode.
|
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.locking | |
org.infinispan.notifications.cachelistener |
Cache -specific notifications and eventing. |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.util.concurrent.locks |
Lock and synchronization related classes, tools and utilities.
|
Modifier and Type | Method and Description |
---|---|
Object |
EvictAllCommand.perform(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
Object |
LockControlCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
StateTransferControlCommand.perform(InvocationContext ctx) |
Object |
LockControlCommand.perform(InvocationContext ignored) |
Object |
CacheViewControlCommand.perform(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
Object |
ValuesCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
SizeCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
KeySetCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
GetKeyValueCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
EntrySetCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
DistributedExecuteCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
protected boolean |
AbstractLocalCommand.noTxModifications(InvocationContext ctx) |
Collection<Object> |
ValuesCommand.perform(InvocationContext ctx) |
Integer |
SizeCommand.perform(InvocationContext ctx) |
Object |
MapReduceCommand.perform(InvocationContext context)
Performs invocation of mapping phase and local reduce phase before returning result to master node
|
Set<Object> |
KeySetCommand.perform(InvocationContext ctx) |
Object |
GetKeyValueCommand.perform(InvocationContext ctx) |
Set<InternalCacheEntry> |
EntrySetCommand.perform(InvocationContext ctx) |
Object |
DistributedExecuteCommand.perform(InvocationContext context)
Performs invocation of Callable and returns result
|
boolean |
DistributedExecuteCommand.shouldInvoke(InvocationContext ctx) |
boolean |
AbstractLocalCommand.shouldInvoke(InvocationContext ctx) |
boolean |
AbstractDataCommand.shouldInvoke(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
Object |
SingleRpcCommand.perform(InvocationContext ctx) |
Object |
MultipleRpcCommand.perform(InvocationContext ctx)
Executes commands replicated to the current cache instance by other cache instances.
|
InternalCacheValue |
ClusteredGetCommand.perform(InvocationContext context)
Invokes a logical "get(key)" on a remote cache and returns results.
|
Modifier and Type | Method and Description |
---|---|
Object |
TxCompletionNotificationCommand.perform(InvocationContext ctx) |
Object |
GetInDoubtTxInfoCommand.perform(InvocationContext ctx) |
List<Xid> |
GetInDoubtTransactionsCommand.perform(InvocationContext ctx) |
Object |
CompleteTransactionCommand.perform(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
Object |
RollbackCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
PrepareCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
CommitCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
PrepareCommand.perform(InvocationContext ignored) |
Object |
AbstractTransactionBoundaryCommand.perform(InvocationContext ctx) |
boolean |
AbstractTransactionBoundaryCommand.shouldInvoke(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
Object |
ReplaceCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
RemoveCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
PutMapCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
PutKeyValueCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
InvalidateL1Command.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
InvalidateCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
EvictCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
ClearCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
Object |
ApplyDeltaCommand.acceptVisitor(InvocationContext ctx,
Visitor visitor) |
protected void |
InvalidateCommand.invalidate(InvocationContext ctx,
Object keyToInvalidate) |
protected void |
RemoveCommand.notify(InvocationContext ctx,
Object value,
boolean isPre) |
protected void |
InvalidateCommand.notify(InvocationContext ctx,
Object value,
boolean isPre) |
void |
EvictCommand.notify(InvocationContext ctx,
Object value,
boolean isPre) |
Object |
VersionedPutKeyValueCommand.perform(InvocationContext ctx) |
Object |
ReplaceCommand.perform(InvocationContext ctx) |
Object |
RemoveCommand.perform(InvocationContext ctx) |
Object |
PutMapCommand.perform(InvocationContext ctx) |
Object |
PutKeyValueCommand.perform(InvocationContext ctx) |
Object |
InvalidateL1Command.perform(InvocationContext ctx) |
Object |
InvalidateCommand.perform(InvocationContext ctx)
Performs an invalidation on a specified entry
|
Object |
EvictCommand.perform(InvocationContext ctx) |
Object |
ClearCommand.perform(InvocationContext ctx) |
Object |
ApplyDeltaCommand.perform(InvocationContext ctx)
Performs an application of delta on a specified entry
|
boolean |
PutMapCommand.shouldInvoke(InvocationContext ctx) |
boolean |
InvalidateL1Command.shouldInvoke(InvocationContext ctx) |
boolean |
ClearCommand.shouldInvoke(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
MVCCEntry |
EntryFactoryImpl.wrapEntryForClear(InvocationContext ctx,
Object key) |
MVCCEntry |
EntryFactory.wrapEntryForClear(InvocationContext ctx,
Object key)
Used for wrapping individual keys when clearing the cache.
|
CacheEntry |
EntryFactoryImpl.wrapEntryForDelta(InvocationContext ctx,
Object deltaKey,
Delta delta) |
CacheEntry |
EntryFactory.wrapEntryForDelta(InvocationContext ctx,
Object deltaKey,
Delta delta)
Used for wrapping Delta entry to be applied to DeltaAware object stored in cache.
|
MVCCEntry |
EntryFactoryImpl.wrapEntryForPut(InvocationContext ctx,
Object key,
InternalCacheEntry icEntry,
boolean undeleteIfNeeded) |
MVCCEntry |
EntryFactory.wrapEntryForPut(InvocationContext ctx,
Object key,
InternalCacheEntry ice,
boolean undeleteIfNeeded)
Used for wrapping a cache entry for addition to cache.
|
CacheEntry |
EntryFactoryImpl.wrapEntryForReading(InvocationContext ctx,
Object key) |
CacheEntry |
EntryFactory.wrapEntryForReading(InvocationContext ctx,
Object key)
Wraps an entry for reading.
|
MVCCEntry |
EntryFactoryImpl.wrapEntryForRemove(InvocationContext ctx,
Object key) |
MVCCEntry |
EntryFactory.wrapEntryForRemove(InvocationContext ctx,
Object key)
Used for wrapping a cache entry for removal.
|
MVCCEntry |
EntryFactoryImpl.wrapEntryForReplace(InvocationContext ctx,
Object key) |
MVCCEntry |
EntryFactory.wrapEntryForReplace(InvocationContext ctx,
Object key)
Used for wrapping a cache entry for replacement.
|
Modifier and Type | Class and Description |
---|---|
class |
InvocationContextFlagsOverride
Wraps an existing
InvocationContext without changing the context directly
but making sure the specified flags are considered enabled. |
class |
SingleKeyNonTxInvocationContext |
class |
TransactionalInvocationContextFlagsOverride
Extension of InvocationContextFlagsOverride to be used when a TxInvocationContext
is required.
|
Modifier and Type | Field and Description |
---|---|
protected ThreadLocal<InvocationContext> |
AbstractInvocationContextContainer.ctxHolder |
Modifier and Type | Method and Description |
---|---|
InvocationContext |
InvocationContext.clone()
Clones the invocation context.
|
InvocationContext |
TransactionalInvocationContextContainer.createInvocationContext(boolean isWrite,
int keyCount) |
InvocationContext |
NonTransactionalInvocationContextContainer.createInvocationContext(boolean isWrite,
int keyCount) |
InvocationContext |
InvocationContextContainer.createInvocationContext(boolean isWrite,
int keyCount)
If we are in a tx scope this will return an
TxInvocationContext . |
InvocationContext |
TransactionalInvocationContextContainer.createInvocationContext(Transaction tx) |
InvocationContext |
NonTransactionalInvocationContextContainer.createInvocationContext(Transaction tx) |
InvocationContext |
InvocationContextContainer.createInvocationContext(Transaction tx)
Creates an invocation context
|
InvocationContext |
InvocationContextContainer.createRemoteInvocationContext(Address origin)
Returns an
NonTxInvocationContext whose NonTxInvocationContext.isOriginLocal() flag will be true. |
InvocationContext |
InvocationContextContainer.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand,
Address origin)
As
InvocationContextContainer.createRemoteInvocationContext(org.infinispan.remoting.transport.Address) , but returning the flags to
the context from the Command if any Flag was set. |
InvocationContext |
AbstractInvocationContextContainer.createRemoteInvocationContextForCommand(VisitableCommand cacheCommand,
Address origin) |
InvocationContext |
TransactionalInvocationContextContainer.createSingleKeyNonTxInvocationContext() |
InvocationContext |
NonTransactionalInvocationContextContainer.createSingleKeyNonTxInvocationContext() |
InvocationContext |
InvocationContextContainer.createSingleKeyNonTxInvocationContext()
Will create an
NonTxInvocationContext with the NonTxInvocationContext.isOriginLocal() returning true. |
InvocationContext |
TransactionalInvocationContextContainer.getInvocationContext() |
InvocationContext |
NonTransactionalInvocationContextContainer.getInvocationContext() |
InvocationContext |
InvocationContextContainer.getInvocationContext(boolean quiet)
Deprecated.
see implementation for notes
|
InvocationContext |
AbstractInvocationContextContainer.getInvocationContext(boolean quiet) |
Constructor and Description |
---|
InvocationContextFlagsOverride(InvocationContext delegate,
Set<Flag> flags)
Wraps an existing
InvocationContext without changing the context directly
but making sure the specified flags are considered enabled. |
Modifier and Type | Interface and Description |
---|---|
interface |
TxInvocationContext
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
Support class for
TxInvocationContext . |
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.
|
Modifier and Type | Method and Description |
---|---|
InvocationContext |
ImmutableContext.clone() |
Modifier and Type | Method and Description |
---|---|
InternalCacheEntry |
DistributionManagerImpl.retrieveFromRemoteSource(Object key,
InvocationContext ctx,
boolean acquireRemoteLock) |
InternalCacheEntry |
DistributionManager.retrieveFromRemoteSource(Object key,
InvocationContext ctx,
boolean acquireRemoteLock)
Retrieves a cache entry from a remote source.
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
PrePostProcessingCommandInterceptor.doAfterCall(InvocationContext ctx,
VisitableCommand command)
Callback that is invoked after every handleXXX() method defined above.
|
protected boolean |
PrePostProcessingCommandInterceptor.doBeforeCall(InvocationContext ctx,
VisitableCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handleClearCommand(InvocationContext ctx,
ClearCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handleCommitCommand(InvocationContext ctx,
CommitCommand command) |
protected Object |
CommandInterceptor.handleDefault(InvocationContext ctx,
VisitableCommand command)
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) |
protected Object |
PrePostProcessingCommandInterceptor.handleGetKeyValueCommand(InvocationContext ctx,
GetKeyValueCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handlePrepareCommand(InvocationContext ctx,
PrepareCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handlePutKeyValueCommand(InvocationContext ctx,
PutKeyValueCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handlePutMapCommand(InvocationContext ctx,
PutMapCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handleRemoveCommand(InvocationContext ctx,
RemoveCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handleReplaceCommand(InvocationContext ctx,
ReplaceCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handleRollbackCommand(InvocationContext ctx,
RollbackCommand command) |
protected Object |
PrePostProcessingCommandInterceptor.handleSizeCommand(InvocationContext ctx,
SizeCommand command) |
Object |
CommandInterceptor.invokeNextInterceptor(InvocationContext ctx,
VisitableCommand command)
Invokes the next interceptor in the chain.
|
protected boolean |
BaseRpcInterceptor.isLocalModeForced(InvocationContext ctx) |
protected boolean |
BaseRpcInterceptor.isSynchronous(InvocationContext ctx) |
Object |
PrePostProcessingCommandInterceptor.visitClearCommand(InvocationContext ctx,
ClearCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitEvictCommand(InvocationContext ctx,
EvictCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitGetKeyValueCommand(InvocationContext ctx,
GetKeyValueCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitPutKeyValueCommand(InvocationContext ctx,
PutKeyValueCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitPutMapCommand(InvocationContext ctx,
PutMapCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitRemoveCommand(InvocationContext ctx,
RemoveCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitReplaceCommand(InvocationContext ctx,
ReplaceCommand command) |
Object |
PrePostProcessingCommandInterceptor.visitSizeCommand(InvocationContext ctx,
SizeCommand command) |
Modifier and Type | Method and Description |
---|---|
void |
CacheNotifierImpl.notifyCacheEntriesEvicted(Collection<InternalCacheEntry> entries,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntriesEvicted(Collection<InternalCacheEntry> entries,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntriesEvicted event.
|
void |
CacheNotifierImpl.notifyCacheEntryActivated(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryActivated(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryActivated event.
|
void |
CacheNotifierImpl.notifyCacheEntryCreated(Object key,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryCreated(Object key,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryCreated event.
|
void |
CacheNotifierImpl.notifyCacheEntryEvicted(Object key,
Object value,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryEvicted(Object key,
Object value,
InvocationContext ctx)
Syntactic sugar
|
void |
CacheNotifierImpl.notifyCacheEntryInvalidated(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryInvalidated(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryInvalidated event.
|
void |
CacheNotifierImpl.notifyCacheEntryLoaded(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryLoaded(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryLoaded event.
|
void |
CacheNotifierImpl.notifyCacheEntryModified(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryModified(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryModified event.
|
void |
CacheNotifierImpl.notifyCacheEntryPassivated(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryPassivated(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryPassivated event.
|
void |
CacheNotifierImpl.notifyCacheEntryRemoved(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryRemoved(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryRemoved event.
|
void |
CacheNotifierImpl.notifyCacheEntryVisited(Object key,
Object value,
boolean pre,
InvocationContext ctx) |
void |
CacheNotifier.notifyCacheEntryVisited(Object key,
Object value,
boolean pre,
InvocationContext ctx)
Notifies all registered listeners of a CacheEntryVisited event.
|
void |
CacheNotifierImpl.notifyTransactionCompleted(GlobalTransaction transaction,
boolean successful,
InvocationContext ctx) |
void |
CacheNotifier.notifyTransactionCompleted(GlobalTransaction transaction,
boolean successful,
InvocationContext ctx)
Notifies all registered listeners of a transaction completion event.
|
void |
CacheNotifierImpl.notifyTransactionRegistered(GlobalTransaction globalTransaction,
InvocationContext ctx) |
void |
CacheNotifier.notifyTransactionRegistered(GlobalTransaction globalTransaction,
InvocationContext ctx)
Notifies all registered listeners of a transaction registration event.
|
Modifier and Type | Method and Description |
---|---|
boolean |
StateTransferLockImpl.acquireForCommand(InvocationContext ctx,
WriteCommand command) |
boolean |
StateTransferLock.acquireForCommand(InvocationContext ctx,
WriteCommand command) |
void |
StateTransferLockImpl.releaseForCommand(InvocationContext ctx,
WriteCommand command) |
void |
StateTransferLock.releaseForCommand(InvocationContext ctx,
WriteCommand command) |
void |
StateTransferLockImpl.waitForStateTransferToEnd(InvocationContext ctx,
VisitableCommand command,
int newCacheViewId) |
void |
StateTransferLock.waitForStateTransferToEnd(InvocationContext ctx,
VisitableCommand command,
int newCacheViewId)
Release the state lock temporarily in order to allow a pending state transfer to start.
|
Modifier and Type | Method and Description |
---|---|
boolean |
LockManagerImpl.acquireLock(InvocationContext ctx,
Object key) |
boolean |
LockManager.acquireLock(InvocationContext ctx,
Object key)
Attempts to lock an entry if the lock isn't already held in the current scope, and records the lock in the
context.
|
boolean |
LockManagerImpl.acquireLock(InvocationContext ctx,
Object key,
long timeoutMillis) |
boolean |
LockManager.acquireLock(InvocationContext ctx,
Object key,
long timeoutMillis) |
boolean |
LockManagerImpl.acquireLockNoCheck(InvocationContext ctx,
Object key) |
boolean |
LockManager.acquireLockNoCheck(InvocationContext ctx,
Object key)
Same as
LockManager.acquireLock(org.infinispan.context.InvocationContext, Object) , but doesn't check whether the
lock is already acquired by the caller. |
protected long |
LockManagerImpl.getLockAcquisitionTimeout(InvocationContext ctx) |
boolean |
LockManagerImpl.lockAndRecord(Object key,
InvocationContext ctx,
long timeoutMillis) |
boolean |
LockManager.lockAndRecord(Object key,
InvocationContext ctx,
long timeoutMillis)
Acquires a lock of type lockType, on a specific entry in the cache.
|
boolean |
DeadlockDetectingLockManager.lockAndRecord(Object key,
InvocationContext ctx,
long lockTimeout) |
void |
LockManagerImpl.unlockAll(InvocationContext ctx) |
void |
LockManager.unlockAll(InvocationContext ctx)
Releases locks present in an invocation context and transaction entry, if one is available.
|
Copyright © 2012 JBoss by Red Hat. All Rights Reserved.