A B C D E F G H I J K L M N O P R S T U V W X Z _

A

AbstractCacheLoader - Class in org.jboss.cache.loader
A convenience abstract implementation of a CacheLoader.
AbstractCacheLoader() - Constructor for class org.jboss.cache.loader.AbstractCacheLoader
 
AbstractDelegatingCacheLoader - Class in org.jboss.cache.loader
AbstractDelegatingCacheLoader provides standard functionality for a cache loader that simply delegates each operation defined in the cache loader interface to the underlying cache loader, basically acting as a proxy to the real cache loader.
AbstractDelegatingCacheLoader(CacheLoader) - Constructor for class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
AbstractInvocationDelegate - Class in org.jboss.cache.invocation
The JBoss Cache hand-wired interceptor stack.
AbstractInvocationDelegate() - Constructor for class org.jboss.cache.invocation.AbstractInvocationDelegate
 
AbstractMarshaller - Class in org.jboss.cache.marshall
Abstract AbstractMarshaller for JBoss Cache.
AbstractMarshaller() - Constructor for class org.jboss.cache.marshall.AbstractMarshaller
 
AbstractNode<K,V> - Class in org.jboss.cache
Base class for UnversionedNode.
AbstractNode() - Constructor for class org.jboss.cache.AbstractNode
 
acquire(Object, long, NodeLock.LockType) - Method in class org.jboss.cache.lock.IdentityLock
 
acquire(Object, long, NodeLock.LockType) - Method in interface org.jboss.cache.lock.NodeLock
 
acquireAll(Object, long, NodeLock.LockType) - Method in class org.jboss.cache.lock.IdentityLock
 
acquireAll(Object, long, NodeLock.LockType, boolean) - Method in class org.jboss.cache.lock.IdentityLock
 
acquireAll(Object, long, NodeLock.LockType) - Method in interface org.jboss.cache.lock.NodeLock
Recursively acquire locks for this node and all subnodes, including internal Fqns such as buddy backup subtrees.
acquireAll(Object, long, NodeLock.LockType, boolean) - Method in interface org.jboss.cache.lock.NodeLock
Same as the overloaded NodeLock.acquire(Object, long, org.jboss.cache.lock.NodeLock.LockType) except that you can optionally specify that internal Fqns - such as buddy backup subtrees - can be excluded when acquiring locks.
acquireAllLocks(List<Fqn>, boolean) - Method in class org.jboss.cache.lock.StripedLock
Acquires locks on all fqns passed in.
acquireLock(Fqn, boolean) - Method in class org.jboss.cache.lock.StripedLock
Blocks until a lock is acquired.
acquireLocksForStateTransfer(NodeSPI, Object, long, boolean, boolean) - Method in class org.jboss.cache.statetransfer.StateTransferManager
Acquires locks on a root node for an owner for state transfer.
acquireReadLock(Object, long) - Method in class org.jboss.cache.lock.IdentityLock
Acquire a read lock with a timeout period of timeout milliseconds.
acquireReadLock(Object, long) - Method in interface org.jboss.cache.lock.NodeLock
Acquires a read lock with a timeout period of timeout milliseconds.
acquireWriteLock(Object, long) - Method in class org.jboss.cache.lock.IdentityLock
Acquire a write lock with a timeout of timeout milliseconds.
acquireWriteLock(Object, long) - Method in interface org.jboss.cache.lock.NodeLock
Acquires a write lock with a timeout of timeout milliseconds.
activate() - Method in interface org.jboss.cache.Region
Activates this region for replication.
activate() - Method in class org.jboss.cache.RegionImpl
 
activate(Fqn) - Method in class org.jboss.cache.RegionManager
Activates unmarshalling of replication messages for the region rooted in the given Fqn.
activateIfEmpty() - Method in interface org.jboss.cache.Region
Activates this region for replication, but if the Fqn that represents this region already exists and either contains data or children, no state transfers take place.
activateIfEmpty() - Method in class org.jboss.cache.RegionImpl
 
activateIfEmpty(Fqn) - Method in class org.jboss.cache.RegionManager
Attempts to activate a given region rooted at a given Fqn, similar to RegionManager.activate(Fqn) except that if the fqn is currently already in use (probably already been activated) this method is a no-op.
activationChangeNodes - Variable in class org.jboss.cache.RegionManager
 
ActivationInterceptor - Class in org.jboss.cache.interceptors
Loads nodes that don't exist at the time of the call into memory from the CacheLoader.
ActivationInterceptor() - Constructor for class org.jboss.cache.interceptors.ActivationInterceptor
 
ActivationInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing activation statistics
activeStatusChanged(boolean) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Method called when the node either becomes the coordinator or stops being the coordinator.
activeWriter_ - Variable in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
add(MethodCall) - Method in class org.jboss.cache.cluster.ReplicationQueue
Adds a new method call.
add(int) - Method in class org.jboss.cache.util.BitEncodedIntegerSet
Adds an integer to the set.
add(E) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
addAll(BitEncodedIntegerSet) - Method in class org.jboss.cache.util.BitEncodedIntegerSet
Adds all elements of another BitEncodedIntegerSet to the current set.
addAll(Collection<? extends E>) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
addBuddies(Collection<Address>) - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
addCacheListener(Object) - Method in interface org.jboss.cache.Cache
Adds a CacheListener-annotated object to the entire cache.
addCacheListener(Fqn<?>, Object) - Method in interface org.jboss.cache.Cache
Adds a CacheListener-annotated object to a given region.
addCacheListener(Object) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
addCacheListener(Fqn, Object) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
addCacheListener(Object) - Method in class org.jboss.cache.notifications.Notifier
Adds a cache listener to the list of cache listeners registered.
addCacheLoader(CacheLoader, CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Adds a cache loader to the chain (always added at the end of the chain)
addCacheLoaderModification(MethodCall) - Method in class org.jboss.cache.transaction.TransactionEntry
 
addCacheLoaderModification(GlobalTransaction, MethodCall) - Method in class org.jboss.cache.transaction.TransactionTable
 
addChild(Object, Node<K, V>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
addChild(Fqn<?>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
addChild(Fqn<?>) - Method in interface org.jboss.cache.Node
Adds a child node with the given Fqn under the current node.
addChild(Object, Node<K, V>) - Method in interface org.jboss.cache.NodeSPI
Adds or replaces a child by name.
addChild(WorkspaceNode<K, V>) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Adds a given WorkspaceNode to the current node's child map
addChild(Fqn) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
addChild(WorkspaceNode<K, V>) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
addChild(Object, Node) - Method in class org.jboss.cache.UnversionedNode
 
addChildConfig(ConfigurationComponent) - Method in class org.jboss.cache.config.ConfigurationComponent
 
addChildConfigs(Collection<? extends ConfigurationComponent>) - Method in class org.jboss.cache.config.ConfigurationComponent
 
addChildDirect(Fqn) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
addChildDirect(Fqn, boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
addChildDirect(Object, boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
addChildDirect(NodeSPI<K, V>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
addChildDirect(Fqn) - Method in interface org.jboss.cache.NodeSPI
Adds a child directly to a Node.
addChildDirect(Fqn, boolean) - Method in interface org.jboss.cache.NodeSPI
Same as NodeSPI.addChildDirect(Fqn) except that it optionally allows you to suppress notification events for the creation of this node.
addChildDirect(Object, boolean) - Method in interface org.jboss.cache.NodeSPI
Same as NodeSPI.addChildDirect(Fqn, boolean) except that it just takes a child name
addChildDirect(NodeSPI<K, V>) - Method in interface org.jboss.cache.NodeSPI
Directly adds the node passed in to the children map of the current node.
addChildDirect(NodeSPI) - Method in class org.jboss.cache.UnversionedNode
 
addChildDirect(Fqn) - Method in class org.jboss.cache.UnversionedNode
 
addChildDirect(Fqn, boolean) - Method in class org.jboss.cache.UnversionedNode
 
addChildDirect(Object, boolean) - Method in class org.jboss.cache.UnversionedNode
 
addChildMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
addChildMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
addComponentDependencies(ComponentRegistry.Component, boolean) - Method in class org.jboss.cache.factories.ComponentRegistry
 
addedEntries - Variable in class org.jboss.cache.util.Util.MapModifications
 
addErroneousAttribute(String) - Method in exception org.jboss.cache.config.ConfigurationException
 
addIndividualCacheLoaderConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.config.CacheLoaderConfig
 
addInterceptor(Interceptor, int) - Method in class org.jboss.cache.CacheImpl
 
addInterceptor(Interceptor, Class<? extends Interceptor>) - Method in class org.jboss.cache.CacheImpl
 
addInterceptor(Interceptor, int) - Method in interface org.jboss.cache.CacheSPI
Adds a custom interceptor to the interceptor chain, at specified position, where the first interceptor in the chain is at position 0 and the last one at getInterceptorChain().size() - 1.
addInterceptor(Interceptor, Class<? extends Interceptor>) - Method in interface org.jboss.cache.CacheSPI
Adds a custom interceptor to the interceptor chain, after an instance of the specified interceptor type.
addInterceptor(Interceptor, int) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
addInterceptor(Interceptor, Class<? extends Interceptor>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
addInvocationLockAcquired(NodeLock) - Method in class org.jboss.cache.InvocationContext
 
addInvocationLocksAcquired(Collection<NodeLock>) - Method in class org.jboss.cache.InvocationContext
 
addLock(NodeLock) - Method in class org.jboss.cache.transaction.TransactionEntry
Adds a lock to the end of the lock list, if it isn't already present.
addLock(GlobalTransaction, NodeLock) - Method in class org.jboss.cache.transaction.TransactionTable
Adds a lock to the global transaction.
addLocks(Collection<NodeLock>) - Method in class org.jboss.cache.transaction.TransactionEntry
Add multiple locks to the lock list.
addLocks(GlobalTransaction, Collection<NodeLock>) - Method in class org.jboss.cache.transaction.TransactionTable
Adds a collection of locks to the global transaction.
addModification(MethodCall) - Method in class org.jboss.cache.transaction.TransactionEntry
Adds a modification to the modification list.
addModification(GlobalTransaction, MethodCall) - Method in class org.jboss.cache.transaction.TransactionTable
Adds a motification to the global transaction.
addNode(WorkspaceNode<K, V>) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
Is thread safe so you dont need to deal with synchronising access to this method.
addNode(WorkspaceNode<K, V>) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
addNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
addNodeEntry(NodeEntry) - Method in interface org.jboss.cache.eviction.EvictionQueue
Add a NodeEntry to the queue.
addNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.FIFOQueue
 
addNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.LFUQueue
 
addNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.LRUQueue
 
addNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.MRUQueue
 
addNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.NullEvictionQueue
No-op
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
addReader(Object) - Method in class org.jboss.cache.lock.LockMap
Adding a reader owner.
addRegionToProcess(Region) - Method in class org.jboss.cache.eviction.EvictionTimerTask
Add a MarshRegion to process by the Eviction Thread.
addRemovedNode(Fqn) - Method in class org.jboss.cache.transaction.TransactionEntry
Adds the node that has been removed.
addToEnvironment(String, Object) - Method in class org.jboss.cache.transaction.DummyContext
Adds a new environment property to the environment of this context.
addUndoOperation(GlobalTransaction, MethodCall) - Method in class org.jboss.cache.CacheImpl
Adds an undo operatoin to the transaction table.
addUndoOperation(MethodCall) - Method in class org.jboss.cache.transaction.TransactionEntry
Adds an undo operation to the undo list.
addUndoOperation(GlobalTransaction, MethodCall) - Method in class org.jboss.cache.transaction.TransactionTable
Adds an undo operation to the global transaction.
AdjListJDBCCacheLoader - Class in org.jboss.cache.loader
Adjacency List Model is the model of persisting trees in which each children holds a reference to its parent.
AdjListJDBCCacheLoader() - Constructor for class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
AdjListJDBCCacheLoaderConfig - Class in org.jboss.cache.loader
AdjListJDBCCacheLoaderConfig
AdjListJDBCCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
afterCompletion(int) - Method in class org.jboss.cache.interceptors.OrderedSynchronizationHandler
 
algorithm - Variable in class org.jboss.cache.eviction.LRUPolicy
 
allowInvocations() - Method in enum org.jboss.cache.CacheStatus
 
allowReader() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
Override this method to change to reader preference *
allowTombstones - Variable in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
announceBuddyPoolName(Address, String) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
asList(Interceptor) - Static method in class org.jboss.cache.factories.InterceptorChainFactory
 
assertIsConstructed() - Method in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
assertTransactionValid(InvocationContext) - Method in class org.jboss.cache.interceptors.Interceptor
Tests whether the caller is in a valid transaction.
assertTypeConstructable(Class, Class...) - Method in class org.jboss.cache.factories.ComponentFactory
 
assertValid() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
assignToBuddyGroup(BuddyGroup, Map<Fqn, byte[]>) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
AsyncCacheLoader - Class in org.jboss.cache.loader
The AsyncCacheLoader is a delegating cache loader that extends AbstractDelegatingCacheLoader overriding methods to that should not just delegate the operation to the underlying cache loader.
AsyncCacheLoader() - Constructor for class org.jboss.cache.loader.AsyncCacheLoader
 
AsyncCacheLoader(CacheLoader) - Constructor for class org.jboss.cache.loader.AsyncCacheLoader
 
AsyncCacheLoaderConfig - Class in org.jboss.cache.loader
 
AsyncCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.AsyncCacheLoaderConfig
Default constructor.
ATTR - Static variable in class org.jboss.cache.factories.XmlConfigurationParser
 
ATTR - Static variable in class org.jboss.cache.xml.XmlHelper
The <attribute> tag which forms the bulk of JBoss Cache configuration elements
await() - Method in class org.jboss.cache.util.ThreadGate
Waits for the gate to open.
await(long) - Method in class org.jboss.cache.util.ThreadGate
Waits for the gate to open or the specified time to elapse.
awaitForPushToFinish(Future, int, TimeUnit) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Method that waits for the in-memory to cache loader state to finish.

B

BASE_PREFIX - Static variable in class org.jboss.cache.jmx.JmxUtil
 
BaseEvictionAlgorithm - Class in org.jboss.cache.eviction
Abstract Event Processing Eviction Algorithm.
BaseEvictionAlgorithm() - Constructor for class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
BaseEvictionPolicy - Class in org.jboss.cache.eviction
Base class implementation of EvictionPolicy and TreeCacheListener.
BaseEvictionPolicy() - Constructor for class org.jboss.cache.eviction.BaseEvictionPolicy
 
BaseRpcInterceptor - Class in org.jboss.cache.interceptors
Acts as a base for all RPC calls - subclassed by ReplicationInterceptor and OptimisticReplicationInterceptor.
BaseRpcInterceptor() - Constructor for class org.jboss.cache.interceptors.BaseRpcInterceptor
 
BaseSortedEvictionAlgorithm - Class in org.jboss.cache.eviction
An abstract SortedEvictionAlgorithm.
BaseSortedEvictionAlgorithm() - Constructor for class org.jboss.cache.eviction.BaseSortedEvictionAlgorithm
 
BaseTransactionalContextInterceptor - Class in org.jboss.cache.interceptors
Class providing some base functionality around manipulating transactions and global transactions withing invocation contexts.
BaseTransactionalContextInterceptor() - Constructor for class org.jboss.cache.interceptors.BaseTransactionalContextInterceptor
 
BatchModeTransactionManager - Class in org.jboss.cache.transaction
Not really a transaction manager in the truest sense of the word.
BatchModeTransactionManager() - Constructor for class org.jboss.cache.transaction.BatchModeTransactionManager
 
BatchModeTransactionManagerLookup - Class in org.jboss.cache.transaction
Returns an instance of BatchModeTransactionManager.
BatchModeTransactionManagerLookup() - Constructor for class org.jboss.cache.transaction.BatchModeTransactionManagerLookup
 
BdbjeCacheLoader - Class in org.jboss.cache.loader.bdbje
A persistent CacheLoader based on Berkeley DB Java Edition.
BdbjeCacheLoader() - Constructor for class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
 
BdbjeCacheLoaderConfig - Class in org.jboss.cache.loader.bdbje
 
BdbjeCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
BeanUtils - Class in org.jboss.cache.util
Simple JavaBean manipulation helper methods
BeanUtils() - Constructor for class org.jboss.cache.util.BeanUtils
 
beforeCompletion() - Method in class org.jboss.cache.interceptors.OrderedSynchronizationHandler
 
begin() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Starts a new transaction, and associate it with the calling thread.
begin() - Method in class org.jboss.cache.transaction.DummyUserTransaction
Starts a new transaction, and associate it with the calling thread.
bind(Name, Object) - Method in class org.jboss.cache.transaction.DummyContext
Binds a name to an object.
bind(String, Object) - Method in class org.jboss.cache.transaction.DummyContext
Binds a name to an object.
BitEncodedIntegerSet - Class in org.jboss.cache.util
A Set that encodes integers as bits in a long.
BitEncodedIntegerSet() - Constructor for class org.jboss.cache.util.BitEncodedIntegerSet
 
block() - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
block() - Method in class org.jboss.cache.RPCManagerImpl.MembershipListenerAdaptor
Indicates that a channel has received a BLOCK event from FLUSH protocol.
blockChannelMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
blockChannelMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
bootstrap(CacheImpl, CacheSPI, Configuration) - Method in class org.jboss.cache.DefaultCacheFactory
Bootstraps this factory with a Configuration and a ComponentRegistry
breakTransactionLock(NodeLock, GlobalTransaction, boolean, TransactionTable, TransactionManager) - Static method in class org.jboss.cache.lock.LockUtil
 
broadcast(Event) - Method in class org.jboss.cache.jmx.CacheNotificationListener
 
broadcastCommit(GlobalTransaction, InvocationContext) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
broadcastPrepare(MethodCall, GlobalTransaction, InvocationContext) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
broadcastRollback(GlobalTransaction, InvocationContext) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
BUDDY_BACKUP_SUBTREE - Static variable in class org.jboss.cache.buddyreplication.BuddyManager
Constants representng the buddy backup subtree
BUDDY_BACKUP_SUBTREE_FQN - Static variable in class org.jboss.cache.buddyreplication.BuddyManager
 
BuddyGroup - Class in org.jboss.cache.buddyreplication
Value object that represents a buddy group
BuddyGroup() - Constructor for class org.jboss.cache.buddyreplication.BuddyGroup
 
BuddyGroupChanged - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a buddy group changes.
BuddyGroupChangedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with BuddyGroupChanged.
BuddyLocator - Interface in org.jboss.cache.buddyreplication
Buddy Locators help the BuddyManager select buddies for its buddy group.
BuddyManager - Class in org.jboss.cache.buddyreplication
Class that manages buddy replication groups.
BuddyManager() - Constructor for class org.jboss.cache.buddyreplication.BuddyManager
 
BuddyManager(BuddyReplicationConfig) - Constructor for class org.jboss.cache.buddyreplication.BuddyManager
 
BuddyManager.ViewChangeListener - Class in org.jboss.cache.buddyreplication
 
BuddyManager.ViewChangeListener() - Constructor for class org.jboss.cache.buddyreplication.BuddyManager.ViewChangeListener
 
BuddyManagerFactory - Class in org.jboss.cache.factories
Buddy manager factory
BuddyManagerFactory() - Constructor for class org.jboss.cache.factories.BuddyManagerFactory
 
BuddyNotInitException - Exception in org.jboss.cache.buddyreplication
Exception to depict that a buddy has not been initialised to participate in any comms
BuddyNotInitException() - Constructor for exception org.jboss.cache.buddyreplication.BuddyNotInitException
 
BuddyNotInitException(String) - Constructor for exception org.jboss.cache.buddyreplication.BuddyNotInitException
 
BuddyNotInitException(String, Throwable) - Constructor for exception org.jboss.cache.buddyreplication.BuddyNotInitException
 
BuddyReplicationConfig - Class in org.jboss.cache.config
 
BuddyReplicationConfig() - Constructor for class org.jboss.cache.config.BuddyReplicationConfig
 
BuddyReplicationConfig.BuddyLocatorConfig - Class in org.jboss.cache.config
 
BuddyReplicationConfig.BuddyLocatorConfig() - Constructor for class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
buildInterceptorChain() - Method in class org.jboss.cache.factories.InterceptorChainFactory
 

C

C3p0ConnectionFactory - Class in org.jboss.cache.loader
Standalone connection factory based on c3p0 connection pooling library
C3p0ConnectionFactory() - Constructor for class org.jboss.cache.loader.C3p0ConnectionFactory
 
Cache<K,V> - Interface in org.jboss.cache
Interface for a Cache where data mappings are grouped and stored in a tree data structure consisting of Nodes.
cache - Variable in class org.jboss.cache.interceptors.Interceptor
 
cache - Variable in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
cache - Variable in class org.jboss.cache.loader.AbstractCacheLoader
 
cache_ - Variable in class org.jboss.cache.eviction.BaseEvictionPolicy
 
CACHE_TYPE_KEY - Static variable in class org.jboss.cache.jmx.JmxUtil
 
CacheBlocked - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a JGroups BLOCK event occurs.
CacheBlockedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with CacheBlocked.
CacheConfigsXmlParser - Class in org.jboss.cache.factories
Parser able to parse a series of cache configurations stored in an XML document with the following structure: ....
CacheConfigsXmlParser() - Constructor for class org.jboss.cache.factories.CacheConfigsXmlParser
 
CachedMethod - Class in org.jboss.cache.util.reflect
A cached Method object, so that calls to getParameterTypes, getAnnotations, etc are cached.
CachedMethod(Method) - Constructor for class org.jboss.cache.util.reflect.CachedMethod
 
CacheException - Exception in org.jboss.cache
Thrown when operations on Cache or Node fail unexpectedly.
CacheException() - Constructor for exception org.jboss.cache.CacheException
 
CacheException(Throwable) - Constructor for exception org.jboss.cache.CacheException
 
CacheException(String) - Constructor for exception org.jboss.cache.CacheException
 
CacheException(String, Throwable) - Constructor for exception org.jboss.cache.CacheException
 
CacheFactory<K,V> - Interface in org.jboss.cache
This factory constructs a cache from a given or default configuration set.
CacheImpl - Class in org.jboss.cache
The default implementation class of Cache and CacheSPI.
CacheImpl() - Constructor for class org.jboss.cache.CacheImpl
Constructs an uninitialized CacheImpl.
CacheImpl(Configuration) - Constructor for class org.jboss.cache.CacheImpl
Constructs an uninitialized CacheImpl.
CacheInjectionMethods - Annotation Type in org.jboss.cache.factories.annotations
If this is set on a class, then all methods on that class (and superclasses) annotated with @Inject are cached in the component registry.
CacheInvocationDelegate<K,V> - Class in org.jboss.cache.invocation
The delegate that users (and interceptor authors) interact with when they create a cache by using a cache factory.
CacheInvocationDelegate() - Constructor for class org.jboss.cache.invocation.CacheInvocationDelegate
 
CacheJmxWrapper<K,V> - Class in org.jboss.cache.jmx
Wrapper class that exposes a JMX management interface for an instance of CacheImpl.
CacheJmxWrapper() - Constructor for class org.jboss.cache.jmx.CacheJmxWrapper
 
CacheJmxWrapper(Cache<K, V>) - Constructor for class org.jboss.cache.jmx.CacheJmxWrapper
 
CacheJmxWrapperMBean<K,V> - Interface in org.jboss.cache.jmx
JMX interface to the Cache.
CacheListener - Annotation Type in org.jboss.cache.notifications.annotation
Class-level annotation used to annotate an object as being a valid cache listener.
CacheLoader - Interface in org.jboss.cache.loader
A CacheLoader implementation persists and load keys to and from secondary storage, such as a database or filesystem.
CacheLoaderAop - Interface in org.jboss.cache.loader
Responsible for storing and retrieving objects to/from secondary storage.
CacheLoaderConfig - Class in org.jboss.cache.config
Holds the configuration of the cache loader chain.
CacheLoaderConfig() - Constructor for class org.jboss.cache.config.CacheLoaderConfig
 
CacheLoaderConfig.IndividualCacheLoaderConfig - Class in org.jboss.cache.config
Configuration object that holds the confguration of an individual cache loader.
CacheLoaderConfig.IndividualCacheLoaderConfig() - Constructor for class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig - Class in org.jboss.cache.config
Configuration for a SingletonStoreCacheLoader
CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig() - Constructor for class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
CacheLoaderInterceptor - Class in org.jboss.cache.interceptors
Loads nodes that don't exist at the time of the call into memory from the CacheLoader
CacheLoaderInterceptor() - Constructor for class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
CacheLoaderInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing cache loader load statistics
CacheLoaderManager - Class in org.jboss.cache.loader
Manages all cache loader functionality.
CacheLoaderManager() - Constructor for class org.jboss.cache.loader.CacheLoaderManager
 
CacheManager - Interface in org.jboss.cache
Factory and registry for JBoss Cache instances configured using named configurations.
CacheManagerImpl - Class in org.jboss.cache
Basic implementation of CacheManager.
CacheManagerImpl() - Constructor for class org.jboss.cache.CacheManagerImpl
Create a new CacheRegistryImpl.
CacheManagerImpl(ConfigurationRegistry, ChannelFactory) - Constructor for class org.jboss.cache.CacheManagerImpl
Create a new CacheRegistryImpl using the provided ConfigurationRegistry and ChannelFactory.
CacheManagerImpl(String, ChannelFactory) - Constructor for class org.jboss.cache.CacheManagerImpl
Create a new CacheRegistryImpl using the provided ChannelFactory and using the provided file name to create an XmlParsingConfigurationRegistry.
CacheMarshaller200 - Class in org.jboss.cache.marshall
An enhanced marshaller for RPC calls between CacheImpl instances.
CacheMarshaller200() - Constructor for class org.jboss.cache.marshall.CacheMarshaller200
 
CacheMarshaller210 - Class in org.jboss.cache.marshall
An evolution of CacheMarshaller200, created to fix JBCACHE-1211.
CacheMarshaller210() - Constructor for class org.jboss.cache.marshall.CacheMarshaller210
 
CacheMessageListener - Class in org.jboss.cache.remoting.jgroups
JGroups MessageListener
CacheMessageListener() - Constructor for class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
CacheMgmtInterceptor - Class in org.jboss.cache.interceptors
Captures cache management statistics
CacheMgmtInterceptor() - Constructor for class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
CacheMgmtInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing basic cache management statistics
CacheNotificationBroadcaster - Interface in org.jboss.cache.jmx
 
CacheNotificationListener - Class in org.jboss.cache.jmx
A CacheListener that creates JMX notifications from listener events.
CachePrinter - Class in org.jboss.cache.util
Helper that prints the contents of a Cache to a string.
CachePrinter() - Constructor for class org.jboss.cache.util.CachePrinter
 
CacheSPI<K,V> - Interface in org.jboss.cache
A more detailed interface to Cache, which is used when writing plugins for or extending JBoss Cache.
cacheStarted(Event) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader.SingletonStoreListener
Cache started, check whether the node is the coordinator and set the singleton store cache loader's active status.
CacheStarted - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a cache is started.
CacheStartedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with CacheStarted.
CacheStatus - Enum in org.jboss.cache
Various states that an object that has a four stage lifecycle (i.e.
cacheStopped(Event) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader.SingletonStoreListener
 
CacheStopped - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a cache is stopped.
CacheStoppedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with CacheStopped.
CacheStoreInterceptor - Class in org.jboss.cache.interceptors
Writes modifications back to the store on the way out: stores modifications back through the CacheLoader, either after each method call (no TXs), or at TX commit.
CacheStoreInterceptor() - Constructor for class org.jboss.cache.interceptors.CacheStoreInterceptor
 
CacheStoreInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing cache loader statistics
CacheUnblocked - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a JGroups UNBLOCK event occurs.
CacheUnblockedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with CacheUnblocked.
CallInterceptor - Class in org.jboss.cache.interceptors
Always at the end of the chain, directly in front of the cache.
CallInterceptor() - Constructor for class org.jboss.cache.interceptors.CallInterceptor
 
callRemoteMethods(List<Address>, MethodCall, int, boolean, long, RspFilter, boolean) - Method in interface org.jboss.cache.RPCManager
Invokes an RPC call on other caches in the cluster.
callRemoteMethods(List<Address>, MethodCall, int, boolean, long, boolean) - Method in interface org.jboss.cache.RPCManager
Invokes an RPC call on other caches in the cluster.
callRemoteMethods(List<Address>, MethodCall, boolean, boolean, int, boolean) - Method in interface org.jboss.cache.RPCManager
Invokes an RPC call on other caches in the cluster.
callRemoteMethods(List<Address>, MethodCall, int, boolean, long, boolean) - Method in class org.jboss.cache.RPCManagerImpl
 
callRemoteMethods(List<Address>, MethodCall, boolean, boolean, int, boolean) - Method in class org.jboss.cache.RPCManagerImpl
 
callRemoteMethods(List<Address>, MethodCall, int, boolean, long, RspFilter, boolean) - Method in class org.jboss.cache.RPCManagerImpl
 
cancelledWaitingReader() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
cancelledWaitingWriter() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
canIgnoreEvent(Fqn, NodeEventType) - Method in class org.jboss.cache.eviction.BaseEvictionPolicy
 
canIgnoreEvent(Fqn, NodeEventType) - Method in interface org.jboss.cache.eviction.EvictionPolicy
This method will be invoked prior to an event being processed for a node with the specified Fqn.
canIgnoreEvent(Fqn, NodeEventType) - Method in class org.jboss.cache.eviction.ExpirationPolicy
Returns true if it's a visit node event.
canIgnoreEvent(Fqn, NodeEventType) - Method in class org.jboss.cache.eviction.NullEvictionPolicy
Returns true
canIgnoreEvent(Fqn, NodeEventType) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
cf - Variable in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
ChainingCacheLoader - Class in org.jboss.cache.loader
This decorator is used whenever more than one cache loader is configured.
ChainingCacheLoader() - Constructor for class org.jboss.cache.loader.ChainingCacheLoader
 
changeLock() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
checkoutConnection() - Method in class org.jboss.cache.loader.C3p0ConnectionFactory
 
checkResponses(List) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
Checks whether any of the responses are exceptions.
children - Variable in class org.jboss.cache.AbstractNode
 
cleanup() - Method in class org.jboss.cache.transaction.DummyTransactionManagerLookup
 
cleanup(GlobalTransaction) - Method in class org.jboss.cache.transaction.TransactionTable
 
clear() - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
clear() - Method in interface org.jboss.cache.eviction.EvictionQueue
Clear the queue.
clear() - Method in class org.jboss.cache.eviction.FIFOQueue
 
clear() - Method in class org.jboss.cache.eviction.LFUQueue
 
clear() - Method in class org.jboss.cache.eviction.LRUQueue
 
clear() - Method in class org.jboss.cache.eviction.MRUQueue
 
clear() - Method in class org.jboss.cache.eviction.NullEvictionQueue
No-op
clear() - Method in class org.jboss.cache.lock.ThreadLocalMap
 
clear() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
clear() - Method in class org.jboss.cache.util.BitEncodedIntegerSet
Clears the set
clear() - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.jboss.cache.util.DeltaMap
 
clearData(String) - Method in interface org.jboss.cache.Cache
Convenience method that takes in a String represenation of the Fqn.
clearData(Fqn<?>) - Method in interface org.jboss.cache.Cache
Removes the keys and properties from a named node.
clearData(String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
Removes the keys and properties from a node.
clearData(Fqn) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
Removes the keys and properties from a named node.
clearData() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
clearData() - Method in interface org.jboss.cache.Node
Removes all mappings from the node's data map.
clearData() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
clearDataDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
clearDataDirect() - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.clearData() except that it operates directly on the node and bypasses the interceptor chain.
clearDataDirect() - Method in class org.jboss.cache.UnversionedNode
 
clearInvocationLocksAcquired() - Method in class org.jboss.cache.InvocationContext
 
clearNodes() - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
Empties the collection of nodes held by this workspace.
clearNodes() - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
clm - Variable in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
clone() - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
clone() - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
clone() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
clone() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
clone() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
clone() - Method in class org.jboss.cache.config.Configuration
 
clone() - Method in class org.jboss.cache.config.ConfigurationComponent
 
clone() - Method in class org.jboss.cache.config.EvictionConfig
 
clone() - Method in class org.jboss.cache.config.EvictionRegionConfig
 
clone() - Method in class org.jboss.cache.config.Option
 
clone() - Method in class org.jboss.cache.config.RuntimeConfig
 
clone() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
clone() - Method in class org.jboss.cache.eviction.ExpirationConfiguration
 
clone() - Method in class org.jboss.cache.eviction.FIFOConfiguration
 
clone() - Method in class org.jboss.cache.eviction.LFUConfiguration
 
clone() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
clone() - Method in class org.jboss.cache.eviction.MRUConfiguration
 
clone() - Method in class org.jboss.cache.Fqn
Clones the Fqn.
clone() - Method in class org.jboss.cache.InvocationContext
 
clone() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
clone() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
close(Connection) - Method in interface org.jboss.cache.loader.ConnectionFactory
 
close(Connection) - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
close() - Method in class org.jboss.cache.transaction.DummyContext
Closes this context.
close() - Method in class org.jboss.cache.util.ThreadGate
Close the gate.
CLUSTER_KEY - Static variable in class org.jboss.cache.jmx.JmxUtil
 
ClusteredCacheLoader - Class in org.jboss.cache.loader
A cache loader that consults other members in the cluster for values.
ClusteredCacheLoader() - Constructor for class org.jboss.cache.loader.ClusteredCacheLoader
 
ClusteredCacheLoader.ResponseValidityFilter - Class in org.jboss.cache.loader
 
ClusteredCacheLoader.ResponseValidityFilter(List<Address>, Address) - Constructor for class org.jboss.cache.loader.ClusteredCacheLoader.ResponseValidityFilter
 
ClusteredCacheLoaderConfig - Class in org.jboss.cache.loader
 
ClusteredCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
clusteredGet(MethodCall, Boolean) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
A 'clustered get' call, called from a remote ClusteredCacheLoader.
clusteredGetMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
clusteredGetMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
codename - Static variable in class org.jboss.cache.Version
 
commit(GlobalTransaction) - Method in class org.jboss.cache.CacheImpl
Throws UnsupportedOperationException.
commit(Object) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
commit(Object) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
commit(Object) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Commits a transaction.
commit(Object) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Commits the given transaction, or throws IllegalArgumentException if the given key is not associated with an uncommited transaction.
commit(Object) - Method in interface org.jboss.cache.loader.CacheLoader
Commits the transaction.
commit(Object) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Commit the transaction.
commit(Object) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing.
commit(Object) - Method in interface org.jboss.cache.loader.ConnectionFactory
 
commit(Object) - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
commit(Object) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
commit(Object) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
commit() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Commit the transaction associated with the calling thread.
commit() - Method in class org.jboss.cache.transaction.DummyTransaction
Attempt to commit this transaction.
commit() - Method in class org.jboss.cache.transaction.DummyUserTransaction
Attempt to commit this transaction.
commit() - Method in class org.jboss.cache.util.DeltaMap
Commits the changes to the original map.
commitMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
commitMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
compact(boolean, boolean) - Method in class org.jboss.cache.marshall.MarshalledValue
Compacts the references held by this class to a single reference.
compare(Fqn, Fqn) - Method in class org.jboss.cache.FqnComparator
Returns -1 if the first comes before; 0 if they are the same; 1 if the second Fqn comes before.
compareTo(Fqn<?>) - Method in class org.jboss.cache.Fqn
Compares this Fqn to another using FqnComparator.
compareTo(Region) - Method in class org.jboss.cache.RegionImpl
 
compareTo(byte[]) - Static method in class org.jboss.cache.Version
 
ComponentFactory - Class in org.jboss.cache.factories
Factory that creates components used internally within JBoss Cache, and also wires dependencies into the components.
ComponentFactory() - Constructor for class org.jboss.cache.factories.ComponentFactory
 
ComponentName - Annotation Type in org.jboss.cache.factories.annotations
Used with the Inject annotation to specify the name of a component to inject.
componentRegistry - Variable in class org.jboss.cache.factories.ComponentFactory
 
ComponentRegistry - Class in org.jboss.cache.factories
A registry where components which have been created are stored.
ComponentRegistry(Configuration) - Constructor for class org.jboss.cache.factories.ComponentRegistry
Creates an instance of the component registry.
ComponentRegistry.State - Enum in org.jboss.cache.factories
Represents the state of a component
composeName(Name, Name) - Method in class org.jboss.cache.transaction.DummyContext
Composes the name of this context with a name relative to this context.
composeName(String, String) - Method in class org.jboss.cache.transaction.DummyContext
Composes the name of this context with a name relative to this context.
ConcurrentHashSet<E> - Class in org.jboss.cache.util.concurrent
A simple Set implementation backed by a ConcurrentHashMap to deal with the fact that the JDK does not have a proper concurrent Set implementation that uses efficient lock striping.
ConcurrentHashSet() - Constructor for class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
CONFIG_ATTR - Static variable in class org.jboss.cache.xml.XmlHelper
The <config> tag may be embedded in the contents of an <attribute>, to specify more complex configuration for certain parameters.
CONFIG_NAME - Static variable in class org.jboss.cache.factories.CacheConfigsXmlParser
Name of the attribute in a cache-config element that specifies the name of the configuration.
CONFIG_ROOT - Static variable in class org.jboss.cache.factories.CacheConfigsXmlParser
Name of the element that represents an individual cache configuration in a cache configs XML document.
Configuration - Class in org.jboss.cache.config
Encapsulates the configuration of a Cache.
Configuration() - Constructor for class org.jboss.cache.config.Configuration
 
configuration - Variable in class org.jboss.cache.factories.ComponentFactory
 
configuration - Variable in class org.jboss.cache.interceptors.Interceptor
 
configuration - Variable in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
configuration - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
configuration - Variable in class org.jboss.cache.RegionManager
 
Configuration.CacheMode - Enum in org.jboss.cache.config
Cache replication mode.
Configuration.NodeLockingScheme - Enum in org.jboss.cache.config
Cache node locking scheme.
Configuration.ShutdownHookBehavior - Enum in org.jboss.cache.config
Behavior of the JVM shutdown hook registered by the cache
ConfigurationComponent - Class in org.jboss.cache.config
Base superclass of Cache configuration classes that expose some properties that can be changed after the cache is started.
ConfigurationComponent() - Constructor for class org.jboss.cache.config.ConfigurationComponent
 
ConfigurationException - Exception in org.jboss.cache.config
An exception that represents an error in the configuration.
ConfigurationException(Exception) - Constructor for exception org.jboss.cache.config.ConfigurationException
 
ConfigurationException(String) - Constructor for exception org.jboss.cache.config.ConfigurationException
 
ConfigurationException(String, String) - Constructor for exception org.jboss.cache.config.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.jboss.cache.config.ConfigurationException
 
ConfigurationRegistry - Interface in org.jboss.cache.config
A registry for Configurations.
ConnectionFactory - Interface in org.jboss.cache.loader
ConnectionFactory interface defining the operations to be defined by connection providers
ConsoleListener - Class in org.jboss.cache
This class provides a non-graphical view of JBossCache replication events for a replicated cache.
ConsoleListener(CacheSPI) - Constructor for class org.jboss.cache.ConsoleListener
Constructor.
ConsoleListener(CacheSPI, boolean, boolean) - Constructor for class org.jboss.cache.ConsoleListener
Constructor.
construct(String, Class<T>) - Method in class org.jboss.cache.DefaultCacheFactory
 
construct(String, Class<T>) - Method in class org.jboss.cache.factories.BuddyManagerFactory
 
construct(String, Class<T>) - Method in class org.jboss.cache.factories.ComponentFactory
Constructs a component.
construct(String, Class<T>) - Method in class org.jboss.cache.factories.EmptyConstructorFactory
 
construct(String, Class<T>) - Method in class org.jboss.cache.factories.InterceptorChainFactory
Initialises the interceptors with a CacheSPI instance.
construct(String, Class<T>) - Method in class org.jboss.cache.factories.ReplicationQueueFactory
 
construct(String, Class<T>) - Method in class org.jboss.cache.factories.RuntimeConfigAwareFactory
 
construct(String, Class<T>) - Method in class org.jboss.cache.factories.TransactionManagerFactory
 
construct(String, Class<T>) - Method in class org.jboss.cache.NodeFactory
 
constructCache() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
contains(int) - Method in class org.jboss.cache.util.BitEncodedIntegerSet
Tests whether the set contains an integer
contains(Object) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
containsAll(Collection<?>) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
containsKey(Object) - Method in class org.jboss.cache.lock.ThreadLocalMap
 
containsKey(Object) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
containsKey(Object) - Method in class org.jboss.cache.util.DeltaMap
 
containsModifications(InvocationContext) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
containsNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
containsNodeEntry(NodeEntry) - Method in interface org.jboss.cache.eviction.EvictionQueue
Check if queue contains the given NodeEntry.
containsNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.FIFOQueue
 
containsNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.LFUQueue
 
containsNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.LRUQueue
 
containsNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.MRUQueue
 
containsNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns false
containsValue(Object) - Method in class org.jboss.cache.lock.ThreadLocalMap
 
containsValue(Object) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
copy(Map<L, W>) - Static method in class org.jboss.cache.util.MapCopy
Returns a copy of the given map.
copyInvocationScopeOptionsToTxScope(InvocationContext) - Method in class org.jboss.cache.interceptors.BaseTransactionalContextInterceptor
 
correctInterceptorChaining(Interceptor) - Method in class org.jboss.cache.factories.InterceptorChainFactory
The same as InterceptorChainFactory.correctInterceptorChaining(java.util.List) except that it takes in the first interceptor in the chain instead of a list of interceptors, and traverses the chain to generate a list.
correctInterceptorChaining(List<Interceptor>) - Method in class org.jboss.cache.factories.InterceptorChainFactory
"Fixes" the next() and last() pointers for each interceptor, based on the order presented in the list passed in, and also re-assesses dependencies for each interceptor, injecting dependencies accordingingly.
create() - Method in interface org.jboss.cache.Cache
Lifecycle method that initializes configuration state, the root node, etc.
create() - Method in class org.jboss.cache.CacheImpl
Lifecycle method.
create() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
create() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
create() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
create() - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
create() - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
create() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Does nothing since start() does all the work.
create() - Method in interface org.jboss.cache.loader.CacheLoader
Lifecycle method, called when the cache loader is created.
create() - Method in class org.jboss.cache.loader.ChainingCacheLoader
Creates individual cache loaders.
create() - Method in class org.jboss.cache.loader.FileCacheLoader
 
create() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
 
create() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
create() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
create(int, Object...) - Static method in class org.jboss.cache.marshall.MethodCallFactory
Creates and initialised an instance of MethodCall.
create(Address) - Static method in class org.jboss.cache.transaction.GlobalTransaction
 
create() - Method in interface org.jboss.cache.TreeCacheViewMBean
 
create(Map<K, V>) - Static method in class org.jboss.cache.util.DeltaMap
Creates and returns a DeltaMap for an original map.
create() - Static method in class org.jboss.cache.util.DeltaMap
Creates and returns a DeltaMap for an empty map.
createAllowed() - Method in enum org.jboss.cache.CacheStatus
 
createAndAddMarshalledValue(Object, Set<MarshalledValue>, InvocationContext) - Method in class org.jboss.cache.interceptors.MarshalledValueInterceptor
 
createAndWire(Configuration) - Method in class org.jboss.cache.DefaultCacheFactory
 
createBuddyLocator(BuddyReplicationConfig.BuddyLocatorConfig) - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
createCache() - Method in interface org.jboss.cache.CacheFactory
Creates and starts a Cache instance using default configuration settings.
createCache(boolean) - Method in interface org.jboss.cache.CacheFactory
Creates and optionally starts a Cache instance using default configuration settings.
createCache(String) - Method in interface org.jboss.cache.CacheFactory
Creates and starts a Cache instance.
createCache(String, boolean) - Method in interface org.jboss.cache.CacheFactory
Creates Cache instance, and optionally starts it.
createCache(Configuration) - Method in interface org.jboss.cache.CacheFactory
Creates a Cache instance based on a Configuration passed in.
createCache(Configuration, boolean) - Method in interface org.jboss.cache.CacheFactory
Creates Cache instance, and optionally starts it, based on a Configuration passed in.
createCache(InputStream) - Method in interface org.jboss.cache.CacheFactory
Creates a Cache instance based on an InputStream passed in, which should be a stream to a valid XML configuration file.
createCache(InputStream, boolean) - Method in interface org.jboss.cache.CacheFactory
Creates a Cache instance based on an InputStream passed in, which should be a stream to a valid XML configuration file.
createCache(Configuration) - Method in class org.jboss.cache.CacheManagerImpl
Extension point for subclasses, where we actually use a CacheFactory to create a cache.
createCache() - Method in class org.jboss.cache.DefaultCacheFactory
 
createCache(boolean) - Method in class org.jboss.cache.DefaultCacheFactory
 
createCache(String) - Method in class org.jboss.cache.DefaultCacheFactory
 
createCache(String, boolean) - Method in class org.jboss.cache.DefaultCacheFactory
 
createCache(Configuration) - Method in class org.jboss.cache.DefaultCacheFactory
This implementation clones the configuration passed in before using it.
createCache(Configuration, boolean) - Method in class org.jboss.cache.DefaultCacheFactory
This implementation clones the configuration passed in before using it.
createCache(InputStream) - Method in class org.jboss.cache.DefaultCacheFactory
 
createCache(InputStream, boolean) - Method in class org.jboss.cache.DefaultCacheFactory
 
createChild(Object, NodeSPI<K, V>, CacheSPI<K, V>, DataVersion) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Creates a child node.
createChild(Object, NodeSPI<K, V>, CacheSPI<K, V>, DataVersion) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
CREATED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The lifecycle method create has completed
createDataNode(Object, Fqn, NodeSPI<K, V>, Map<K, V>, boolean) - Method in class org.jboss.cache.NodeFactory
Creates a new Node instance.
createDefaultBuddyLocator() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
createDefaultEvictionRegionConfig() - Method in class org.jboss.cache.config.EvictionConfig
Creates an EvictionRegionConfig for the "_default_" region using the default eviction policy class.
createNode(Object, Node<K, V>, Map<K, V>) - Method in class org.jboss.cache.NodeFactory
 
createNodeOfType(Node<K, V>, Object, Node<K, V>, Map<K, V>) - Method in class org.jboss.cache.NodeFactory
 
createPushStateTask() - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Factory method for the creation of a Callable task in charge of pushing in-memory state to cache loader.
createRootDataNode() - Method in class org.jboss.cache.NodeFactory
 
createSubcontext(Name) - Method in class org.jboss.cache.transaction.DummyContext
Creates and binds a new context.
createSubcontext(String) - Method in class org.jboss.cache.transaction.DummyContext
Creates and binds a new context.
createWithNullId(Method, Object...) - Static method in class org.jboss.cache.marshall.MethodCallFactory
Creates and initialised an instance of MethodCall
createWorkspaceNode(NodeSPI<K, V>, TransactionWorkspace) - Method in class org.jboss.cache.NodeFactory
 

D

DATA - Static variable in class org.jboss.cache.loader.FileCacheLoader
CacheImpl data file.
dataGravitationCleanup(Fqn, Fqn) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
dataGravitationCleanupMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
dataGravitationCleanupMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
dataGravitationMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
dataGravitationMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
DataGravitatorInterceptor - Class in org.jboss.cache.interceptors
The Data Gravitator interceptor intercepts cache misses and attempts to gravitate data from other parts of the cluster.
DataGravitatorInterceptor() - Constructor for class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
DataGravitatorInterceptor.ResponseValidityFilter - Class in org.jboss.cache.interceptors
 
DataGravitatorInterceptor.ResponseValidityFilter(List<Address>, Address) - Constructor for class org.jboss.cache.interceptors.DataGravitatorInterceptor.ResponseValidityFilter
 
dataSize() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
dataSize() - Method in interface org.jboss.cache.Node
 
dataSize() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
DataVersion - Interface in org.jboss.cache.optimistic
When versioning data nodes in optimistic locking, a DataVersion is assigned to each node.
DataVersioningException - Exception in org.jboss.cache.optimistic
Denotes exceptions to do with data versioning in optimistic locking
DataVersioningException() - Constructor for exception org.jboss.cache.optimistic.DataVersioningException
 
DataVersioningException(String) - Constructor for exception org.jboss.cache.optimistic.DataVersioningException
 
DataVersioningException(String, Throwable) - Constructor for exception org.jboss.cache.optimistic.DataVersioningException
 
deactivate() - Method in interface org.jboss.cache.Region
Deactivates this region from being replicated.
deactivate() - Method in class org.jboss.cache.RegionImpl
 
deactivate(Fqn) - Method in class org.jboss.cache.RegionManager
Disables unmarshalling of replication messages for the region rooted in the given Fqn.
DeadlockException - Exception in org.jboss.cache.lock
Used when a lock acquisition would cause a deadlock.
DeadlockException(String) - Constructor for exception org.jboss.cache.lock.DeadlockException
Constructor for DeadlockException.
DeadlockException(String, Throwable) - Constructor for exception org.jboss.cache.lock.DeadlockException
 
decodeVersion(short) - Static method in class org.jboss.cache.Version
 
DEFAULT_DOUBLING_SIZE - Static variable in class org.jboss.cache.util.ExposedByteArrayOutputStream
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
DEFAULT_QUEUE_SIZE - Static variable in class org.jboss.cache.loader.AsyncCacheLoader
Default limit on entries to process asynchronously.
DEFAULT_REGION - Static variable in class org.jboss.cache.RegionManager
The default region used in XML configuration files when defining eviction policies.
DEFAULT_REPLICATION_VERSION - Static variable in class org.jboss.cache.config.Configuration
Default replication version, from Version.getVersionShort().
DefaultCacheFactory<K,V> - Class in org.jboss.cache
Default implementation of the CacheFactory interface.
DefaultCacheFactory() - Constructor for class org.jboss.cache.DefaultCacheFactory
 
defaultClassLoader - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
DefaultDataVersion - Class in org.jboss.cache.optimistic
The default implementation of a DataVersion, uses a long to compare versions.
DefaultDataVersion() - Constructor for class org.jboss.cache.optimistic.DefaultDataVersion
Constructs with version 0.
DefaultDataVersion(long) - Constructor for class org.jboss.cache.optimistic.DefaultDataVersion
Constructs with a version number.
DefaultFactoryFor - Annotation Type in org.jboss.cache.factories.annotations
An annotation that is used internally, for defining a DEFAULT factory to be used when constructing components.
defaultInactive - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
DefaultStateTransferGenerator - Class in org.jboss.cache.statetransfer
 
DefaultStateTransferGenerator(CacheSPI) - Constructor for class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
 
DefaultStateTransferIntegrator - Class in org.jboss.cache.statetransfer
 
DefaultStateTransferIntegrator(Fqn, CacheSPI) - Constructor for class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
defaultSynchronous - Variable in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
deleted - Variable in class org.jboss.cache.AbstractNode
 
delimitStream(ObjectOutputStream) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
Places a delimiter marker on the stream
delistResource(XAResource, int) - Method in class org.jboss.cache.transaction.DummyTransaction
Delist an XA resource from this transaction.
DeltaMap<K,V> - Class in org.jboss.cache.util
Wraps an existing map, which is not modified, reflecting modifications in an internal modification set.
deserialize() - Method in class org.jboss.cache.marshall.MarshalledValue
 
destroy() - Method in interface org.jboss.cache.Cache
Lifecycle method that destroys the cache and removes any interceptors/configuration elements.
destroy() - Method in class org.jboss.cache.CacheImpl
Lifecycle method.
Destroy - Annotation Type in org.jboss.cache.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache is destroyed.
destroy() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
destroy() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
destroy() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
destroy() - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
destroy() - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
destroy() - Method in interface org.jboss.cache.loader.CacheLoader
Lifecycle method, called when the cache loader is destroyed.
destroy() - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
destroy() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
destroy() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
destroy() - Method in class org.jboss.cache.notifications.Notifier
 
destroy() - Method in class org.jboss.cache.RegionManager
 
destroy() - Static method in class org.jboss.cache.transaction.BatchModeTransactionManager
 
destroy() - Static method in class org.jboss.cache.transaction.DummyTransactionManager
 
destroy() - Method in interface org.jboss.cache.TreeCacheViewMBean
 
destroyAllowed() - Method in enum org.jboss.cache.CacheStatus
 
DESTROYED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The lifecycle method destroy has completed
destroySubcontext(Name) - Method in class org.jboss.cache.transaction.DummyContext
Destroys the named context and removes it from the namespace.
destroySubcontext(String) - Method in class org.jboss.cache.transaction.DummyContext
Destroys the named context and removes it from the namespace.
diffNodeData(Map<Object, Object>, Map<Object, Object>) - Static method in class org.jboss.cache.util.Util
Calculates the diffs between data maps passed in to NodeModifiedEvent.getData() before and after modification.
DIR_SUFFIX - Static variable in class org.jboss.cache.loader.FileCacheLoader
CacheImpl directory suffix.
disconnect() - Method in interface org.jboss.cache.RPCManager
Disconnects and closes the underlying JGroups channel.
disconnect() - Method in class org.jboss.cache.RPCManagerImpl
 
DOCUMENT_ROOT - Static variable in class org.jboss.cache.factories.CacheConfigsXmlParser
Name of the root element in a cache configs XML document
doMarshall(Fqn, Object) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
doMarshall(Fqn, Object) - Method in class org.jboss.cache.loader.FileCacheLoader
 
doUnmarshall(Fqn, Object) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
doUnmarshall(Fqn, Object) - Method in class org.jboss.cache.loader.FileCacheLoader
 
driverName - Variable in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
dummy_ - Static variable in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
DummyBaseTransactionManager - Class in org.jboss.cache.transaction
 
DummyBaseTransactionManager() - Constructor for class org.jboss.cache.transaction.DummyBaseTransactionManager
 
DummyContext - Class in org.jboss.cache.transaction
 
DummyContext() - Constructor for class org.jboss.cache.transaction.DummyContext
 
DummyContextFactory - Class in org.jboss.cache.transaction
 
DummyContextFactory() - Constructor for class org.jboss.cache.transaction.DummyContextFactory
 
DummyTransaction - Class in org.jboss.cache.transaction
 
DummyTransaction(DummyBaseTransactionManager) - Constructor for class org.jboss.cache.transaction.DummyTransaction
 
DummyTransactionManager - Class in org.jboss.cache.transaction
Simple transaction manager implementation that maintains transaction state in memory only.
DummyTransactionManager() - Constructor for class org.jboss.cache.transaction.DummyTransactionManager
 
DummyTransactionManagerLookup - Class in org.jboss.cache.transaction
Returns an instance of DummyTransactionManager.
DummyTransactionManagerLookup() - Constructor for class org.jboss.cache.transaction.DummyTransactionManagerLookup
 
DummyUserTransaction - Class in org.jboss.cache.transaction
 
DummyUserTransaction(DummyTransactionManager) - Constructor for class org.jboss.cache.transaction.DummyUserTransaction
 
dump() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Dumps the tree to debug.
dump(Object) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Dumps the tree past the key to debug.
dumpRegions() - Method in class org.jboss.cache.RegionManager
Returns a string containing debug information on every region.
dumpStatistics() - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
dumpStatistics() - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
dumpStatistics() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
dumpStatistics() - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
dumpStatistics() - Method in class org.jboss.cache.interceptors.Interceptor
This implementation returns an empty Map.
dumpStatistics() - Method in interface org.jboss.cache.interceptors.InterceptorMBean
Returns a map of the cache interceptor's statistics Map is keyed on statistic names (which are Strings) and values are Objects.
dumpStatistics() - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
dumpStatistics() - Method in class org.jboss.cache.interceptors.PassivationInterceptor
 
dumpStatistics() - Method in class org.jboss.cache.interceptors.TxInterceptor
 
Dynamic - Annotation Type in org.jboss.cache.config
Annotation that marks fields in Configuration as being modifiable even after the cache has started.

E

ElementSizeAlgorithm - Class in org.jboss.cache.eviction
 
ElementSizeAlgorithm() - Constructor for class org.jboss.cache.eviction.ElementSizeAlgorithm
 
ElementSizeConfiguration - Class in org.jboss.cache.eviction
Configuration for ElementSizePolicy.
ElementSizeConfiguration() - Constructor for class org.jboss.cache.eviction.ElementSizeConfiguration
 
ElementSizePolicy - Class in org.jboss.cache.eviction
 
ElementSizePolicy() - Constructor for class org.jboss.cache.eviction.ElementSizePolicy
 
ElementSizeQueue - Class in org.jboss.cache.eviction
 
EmptyConstructorFactory - Class in org.jboss.cache.factories
Simple factory that just uses reflection and an empty constructor of the component type.
EmptyConstructorFactory() - Constructor for class org.jboss.cache.factories.EmptyConstructorFactory
 
emptyRecycleQueue() - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Empty the Recycle Queue.
encodeVersion(int, int, int) - Static method in class org.jboss.cache.Version
 
endRead() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
Called upon termination of a read.
endWrite() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
Called upon termination of a write.
enlistResource(XAResource) - Method in class org.jboss.cache.transaction.DummyTransaction
Enlist an XA resource with this transaction.
entrySet() - Method in class org.jboss.cache.lock.ThreadLocalMap
 
entrySet() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
entrySet() - Method in class org.jboss.cache.util.DeltaMap
 
entrySet() - Method in class org.jboss.cache.util.MapCopy
 
equals(Object) - Method in class org.jboss.cache.AbstractNode
 
equals(Object) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
equals(Object) - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
equals(Object) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
equals(Object) - Method in class org.jboss.cache.config.CacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
equals(Object) - Method in class org.jboss.cache.config.Configuration
 
equals(Object) - Method in class org.jboss.cache.config.EvictionConfig
 
equals(Object) - Method in class org.jboss.cache.config.EvictionRegionConfig
 
equals(Object) - Method in class org.jboss.cache.config.Option
 
equals(Object) - Method in class org.jboss.cache.config.RuntimeConfig
 
equals(Object) - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
equals(Object) - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
equals(Object) - Method in class org.jboss.cache.eviction.FIFOConfiguration
 
equals(Object) - Method in class org.jboss.cache.eviction.LFUConfiguration
 
equals(Object) - Method in class org.jboss.cache.eviction.LRUConfiguration
 
equals(Object) - Method in class org.jboss.cache.eviction.MRUConfiguration
 
equals(Object) - Method in class org.jboss.cache.eviction.NodeEntry
 
equals(Object) - Method in class org.jboss.cache.Fqn
Returns true if obj is a Fqn with the same elements.
equals(Object) - Method in class org.jboss.cache.InvocationContext
 
equals(Object) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
equals(Object) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
equals(Object) - Method in class org.jboss.cache.marshall.MarshalledValue
 
equals(Object) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
equals(Object) - Method in class org.jboss.cache.marshall.NodeData
 
equals(Object) - Method in class org.jboss.cache.notifications.event.EventImpl
 
equals(Object) - Method in class org.jboss.cache.optimistic.DefaultDataVersion
 
equals(Object) - Method in class org.jboss.cache.transaction.GlobalTransaction
 
equals(Object) - Method in class org.jboss.cache.util.BitEncodedIntegerSet
 
equals(Object) - Method in class org.jboss.cache.util.Util.MapModifications
 
equalsExcludingProperties(Object) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
escapeBackslashes(String) - Static method in class org.jboss.cache.xml.XmlHelper
Escapes backslashes ('\') with additional backslashes in a given String, returning a new, escaped String.
Event - Interface in org.jboss.cache.notifications.event
An interface that defines common characteristics of events
Event.Type - Enum in org.jboss.cache.notifications.event
 
EVENT_QUEUE_SIZE - Static variable in class org.jboss.cache.config.EvictionConfig
 
EVENT_QUEUE_SIZE - Static variable in class org.jboss.cache.config.EvictionRegionConfig
 
EVENT_QUEUE_SIZE_DEFAULT - Static variable in class org.jboss.cache.config.EvictionConfig
 
EventImpl - Class in org.jboss.cache.notifications.event
Basic implementation of an event that covers all event types.
EventImpl(boolean, Cache, NodeModifiedEvent.ModificationType, Map, Fqn, Transaction, boolean, Fqn, boolean, View, Event.Type) - Constructor for class org.jboss.cache.notifications.event.EventImpl
 
EventImpl() - Constructor for class org.jboss.cache.notifications.event.EventImpl
 
evict(Fqn<?>, boolean) - Method in interface org.jboss.cache.Cache
Eviction call that evicts the specified Node from memory.
evict(Fqn<?>) - Method in interface org.jboss.cache.Cache
Eviction call that evicts the specified Node from memory.
evict(NodeEntry) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
evict(Fqn) - Method in class org.jboss.cache.eviction.BaseEvictionPolicy
Evict the node under given Fqn from cache.
evict(Fqn) - Method in interface org.jboss.cache.eviction.EvictionPolicy
Evict a node form the underlying cache.
evict(NodeEntry) - Method in class org.jboss.cache.eviction.LRUAlgorithm
 
evict(Fqn) - Method in class org.jboss.cache.eviction.NullEvictionPolicy
No-op
evict(Fqn<?>, boolean) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
evict(Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
evictCacheNode(Fqn) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Evict a node from cache.
EvictedEventNode - Class in org.jboss.cache.eviction
Value object used in evicted event node queue.
EvictedEventNode(Fqn, NodeEventType, int) - Constructor for class org.jboss.cache.eviction.EvictedEventNode
 
EvictedEventNode(Fqn, NodeEventType) - Constructor for class org.jboss.cache.eviction.EvictedEventNode
 
EVICTION_POLICY_CLASS - Static variable in class org.jboss.cache.config.EvictionConfig
 
EvictionAlgorithm - Interface in org.jboss.cache.eviction
Interface for all eviction algorithms.
EvictionConfig - Class in org.jboss.cache.config
 
EvictionConfig() - Constructor for class org.jboss.cache.config.EvictionConfig
 
EvictionConfig(String) - Constructor for class org.jboss.cache.config.EvictionConfig
 
EvictionException - Exception in org.jboss.cache.eviction
 
EvictionException() - Constructor for exception org.jboss.cache.eviction.EvictionException
 
EvictionException(String) - Constructor for exception org.jboss.cache.eviction.EvictionException
 
EvictionException(String, Throwable) - Constructor for exception org.jboss.cache.eviction.EvictionException
 
EvictionInterceptor - Class in org.jboss.cache.interceptors
Eviction Interceptor.
EvictionInterceptor() - Constructor for class org.jboss.cache.interceptors.EvictionInterceptor
 
EvictionPolicy - Interface in org.jboss.cache.eviction
Generic eviction policy interface.
EvictionPolicyConfig - Interface in org.jboss.cache.config
This class encapsulates the configuration element for an eviction policy.
EvictionPolicyConfigBase - Class in org.jboss.cache.eviction
Base implementation of EvictionPolicyConfig.
EvictionPolicyConfigBase() - Constructor for class org.jboss.cache.eviction.EvictionPolicyConfigBase
Can only be instantiated by a subclass.
evictionQueue - Variable in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Contains NodeEntry instances.
EvictionQueue - Interface in org.jboss.cache.eviction
Eviction Queue interface defines a contract for the Eviction Queue implementations used by EvictionPolicies.
EvictionQueueList - Class in org.jboss.cache.eviction
 
EvictionRegionConfig - Class in org.jboss.cache.config
 
EvictionRegionConfig() - Constructor for class org.jboss.cache.config.EvictionRegionConfig
 
EvictionRegionConfig(Fqn, EvictionPolicyConfig) - Constructor for class org.jboss.cache.config.EvictionRegionConfig
 
EvictionTimerTask - Class in org.jboss.cache.eviction
Timer threads to do periodic node clean up by running the eviction policy.
EvictionTimerTask() - Constructor for class org.jboss.cache.eviction.EvictionTimerTask
 
evictNodeMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
evictNodeMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
evictVersionedNodeMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
evictVersionedNodeMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
excludeKeys(Map<K, V>, Set<K>) - Static method in class org.jboss.cache.util.DeltaMap
Creates and returns a DeltaMap for an original map, excluding some key mappings.
excludeKeys(Map<K, V>, K...) - Static method in class org.jboss.cache.util.DeltaMap
Creates and returns a DeltaMap for an original map, excluding some key mappings.
existModifications() - Method in class org.jboss.cache.transaction.TransactionEntry
Returns true if modifications were registered to either modificationList or to class loader modifications list.
exists(String) - Method in class org.jboss.cache.CacheImpl
Checks whether a given node exists in current in-memory state of the cache.
exists(Fqn<?>) - Method in class org.jboss.cache.CacheImpl
Checks whether a given node exists in current in-memory state of the cache.
exists(String, Object) - Method in class org.jboss.cache.CacheImpl
 
exists(Fqn<?>, Object) - Method in class org.jboss.cache.CacheImpl
Checks whether a given key exists in the given node.
exists(Fqn<?>) - Method in interface org.jboss.cache.CacheSPI
Helper method that does a peek and ensures that the result of the peek is not null.
exists(String) - Method in interface org.jboss.cache.CacheSPI
A convenience method that takes a String representation of an Fqn.
exists(String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
exists(Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
exists(Fqn) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
exists(Fqn) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Checks that there is a row for the fqn in the database.
exists(Fqn) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Returns whether the given node exists.
exists(Fqn) - Method in interface org.jboss.cache.loader.CacheLoader
Returns true if the CacheLoader has a node with a Fqn.
exists(Fqn) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Checks whether the CacheLoader has a node with Fqn
exists(Fqn) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
exists(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
exists(Fqn) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Returns whether the given node exists.
exists(Fqn) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
EXISTS - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
exists(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
existsMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
existsMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
EXPIRATION_KEY - Static variable in class org.jboss.cache.eviction.ExpirationConfiguration
Default key name for indicating expiration time.
ExpirationAlgorithm - Class in org.jboss.cache.eviction
Eviction algorithm that uses a key in the Node data that indicates the time the node should be evicted.
ExpirationAlgorithm(ExpirationPolicy) - Constructor for class org.jboss.cache.eviction.ExpirationAlgorithm
Constructs a new algorithm with a policy.
ExpirationConfiguration - Class in org.jboss.cache.eviction
Configuration for indicating the Node key for setting a specific eviction time.
ExpirationConfiguration() - Constructor for class org.jboss.cache.eviction.ExpirationConfiguration
 
ExpirationPolicy - Class in org.jboss.cache.eviction
Returns the ExpirationAlgorithm as the policy's algorithm.
ExpirationPolicy() - Constructor for class org.jboss.cache.eviction.ExpirationPolicy
 
ExposedByteArrayOutputStream - Class in org.jboss.cache.util
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.jboss.cache.util.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.jboss.cache.util.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.jboss.cache.util.ExposedByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
extractAttributes(Element) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
extractFqn(MethodCall) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
extractFqnFromListOfMethodCall(MethodCall) - Method in class org.jboss.cache.marshall.AbstractMarshaller
This is "replicate" call with a list of MethodCall argument.
extractFqnFromMethodCall(MethodCall) - Method in class org.jboss.cache.marshall.AbstractMarshaller
This is "replicate" call with a single MethodCall argument.

F

FAILED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
There has been an error during some operation
fetchPartialState(List<Address>, Fqn, Fqn) - Method in interface org.jboss.cache.RPCManager
Retrieves partial state from remote instances.
fetchPartialState(List<Address>, Fqn) - Method in interface org.jboss.cache.RPCManager
Retrieves partial state from remote instances.
fetchPartialState(List<Address>, Fqn, Fqn) - Method in class org.jboss.cache.RPCManagerImpl
 
fetchPartialState(List<Address>, Fqn) - Method in class org.jboss.cache.RPCManagerImpl
 
FIFOAlgorithm - Class in org.jboss.cache.eviction
First-in-first-out algorithm used to evict nodes.
FIFOAlgorithm() - Constructor for class org.jboss.cache.eviction.FIFOAlgorithm
 
FIFOConfiguration - Class in org.jboss.cache.eviction
Configuration for FIFOPolicy.
FIFOConfiguration() - Constructor for class org.jboss.cache.eviction.FIFOConfiguration
 
FIFOPolicy - Class in org.jboss.cache.eviction
Eviction policy based on the FIFO algorithm where users can specify the max number of nodes.
FIFOPolicy() - Constructor for class org.jboss.cache.eviction.FIFOPolicy
 
FIFOQueue - Class in org.jboss.cache.eviction
FIFO Eviction Queue implementation for FIFO Policy.
FileCacheLoader - Class in org.jboss.cache.loader
Simple file-based CacheLoader implementation.
FileCacheLoader() - Constructor for class org.jboss.cache.loader.FileCacheLoader
 
FileCacheLoaderConfig - Class in org.jboss.cache.loader
 
FileCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.FileCacheLoaderConfig
 
findAndAddFqns(Object[], Set<Fqn>, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
Deprecated. 
findGlobalTransaction(Object[]) - Method in class org.jboss.cache.interceptors.InvocationContextInterceptor
 
findNode(Fqn) - Method in class org.jboss.cache.CacheImpl
Finds a node given a fully qualified name.
flush() - Method in class org.jboss.cache.cluster.ReplicationQueue
Flushes existing method calls.
formatHtml(String) - Static method in class org.jboss.cache.jmx.CacheJmxWrapper
Formats a given String for display as an HTML snippet.
fqn - Variable in class org.jboss.cache.AbstractNode
 
Fqn<E> - Class in org.jboss.cache
A Fully Qualified Name (Fqn) is a list of names (typically Strings but can be any Object), which represent a path to a particular Node or sometimes a Region in a Cache.
Fqn() - Constructor for class org.jboss.cache.Fqn
Constructs a root Fqn
Fqn(List<E>) - Constructor for class org.jboss.cache.Fqn
Constructs a FQN from a list of names.
Fqn(List<E>, boolean) - Constructor for class org.jboss.cache.Fqn
If safe is false, Collections.unmodifiableList() is used to wrap the list passed in.
Fqn(E...) - Constructor for class org.jboss.cache.Fqn
Constructs a Fqn from an array of names.
Fqn(Fqn<E>, Fqn<E>) - Constructor for class org.jboss.cache.Fqn
Constructs a Fqn from a base and relative Fqn.
Fqn(Fqn<E>, List<E>) - Constructor for class org.jboss.cache.Fqn
Constructs a Fqn from a base and a list of relative names.
Fqn(Fqn<E>, E...) - Constructor for class org.jboss.cache.Fqn
Constructs a Fqn from a base and two relative names.
FQN_PATTERN - Static variable in class org.jboss.cache.loader.FileCacheLoader
For fqn, check '*' '<' '>' '|' '"' '?'
fqnColumn - Variable in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
FqnComparator - Class in org.jboss.cache
Compares the order of two FQN.
FqnComparator() - Constructor for class org.jboss.cache.FqnComparator
 
fromMethodCall(MethodCall) - Static method in class org.jboss.cache.InvocationContext
Factory method that creates a context with a given method call.
fromString(String) - Static method in class org.jboss.cache.Fqn
Returns a new Fqn from a string, where the elements are deliminated by one or more separator (Fqn.SEPARATOR) characters.

G

generateNodeDataList(NodeSPI<?, ?>, List<NodeData>) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
 
generateState(Fqn, long, boolean, boolean) - Method in class org.jboss.cache.buddyreplication.BuddyManager
Returns the state for the portion of the cache named by fqn.
generateState(ObjectOutputStream, Node, boolean, boolean, boolean) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
 
generateState(ObjectOutputStream, Node, boolean, boolean, boolean) - Method in interface org.jboss.cache.statetransfer.StateTransferGenerator
 
GenericTransactionManagerLookup - Class in org.jboss.cache.transaction
A transaction manager lookup class that attempts to locate a TransactionManager.
GenericTransactionManagerLookup() - Constructor for class org.jboss.cache.transaction.GenericTransactionManagerLookup
 
get(Fqn<?>, K) - Method in interface org.jboss.cache.Cache
Convenience method that allows for direct access to the data in a Node.
get(String, K) - Method in interface org.jboss.cache.Cache
Convenience method that takes a string representation of an Fqn.
get(int) - Method in class org.jboss.cache.Fqn
 
get(Fqn<?>, K) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
get(String, K) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
get(K) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
get(Fqn) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
get(Fqn) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Returns a map representing a node.
get(Fqn) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
get(Fqn) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Returns a map containing all key-value pairs for the given FQN, or null if the node is not present.
get(Fqn) - Method in interface org.jboss.cache.loader.CacheLoader
Returns all keys and values from the persistent store, given a Fqn
get(Fqn) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Returns all keys and values from the persistent store, given a fully qualified name
get(Fqn) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
get(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
get(Fqn) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Returns a map containing all key-value pairs for the given FQN, or null if the node is not present.
get(Fqn) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
GET - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
get(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
get(Object) - Method in class org.jboss.cache.lock.ThreadLocalMap
 
get() - Method in class org.jboss.cache.marshall.MarshalledValue
 
get(Object) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
get(K) - Method in interface org.jboss.cache.Node
Returns the value to which this node maps the specified key.
get(K) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
get(Transaction) - Method in class org.jboss.cache.transaction.TransactionTable
Returns the global transaction associated with the local transaction.
get(GlobalTransaction) - Method in class org.jboss.cache.transaction.TransactionTable
Returns the local transaction entry for the global transaction.
get(Object) - Method in class org.jboss.cache.UnversionedNode
 
get(Object) - Method in class org.jboss.cache.util.DeltaMap
 
get0(Fqn) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
GET_CHILDREN_NAMES - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
GET_KEY - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
getActivations() - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
getActivations() - Method in interface org.jboss.cache.interceptors.ActivationInterceptorMBean
Returns the number of cache node activations
getActualFqn(Fqn) - Static method in class org.jboss.cache.buddyreplication.BuddyManager
 
getAddress() - Method in class org.jboss.cache.transaction.GlobalTransaction
 
getAllCachedMethods(Class, Class<? extends Annotation>) - Static method in class org.jboss.cache.util.reflect.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllMethods(Class, Class<? extends Annotation>) - Static method in class org.jboss.cache.util.reflect.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllRegions(Region.Type) - Method in class org.jboss.cache.RegionManager
Returns an ordered list of all regions.
getAncestor(int) - Method in class org.jboss.cache.Fqn
Obtains an ancestor of the current Fqn.
getAsInputStreamFromClassLoader(String) - Method in class org.jboss.cache.factories.CacheConfigsXmlParser
 
getAsInputStreamFromClassLoader(String) - Method in class org.jboss.cache.factories.XmlConfigurationParser
 
getAttributes() - Method in class org.jboss.cache.marshall.NodeData
 
getAttributeValue(Element, String, String) - Static method in class org.jboss.cache.xml.XmlHelper
Retrieves the value of a given attribute for the first encountered instance of a tag in an element.
getAverageReadTime() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getAverageReadTime() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns average milliseconds for an attribute read operation This includes both hits and misses.
getAverageWriteTime() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getAverageWriteTime() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns average milliseconds for an attribute write operation
getBackupDataOwners() - Method in class org.jboss.cache.buddyreplication.BuddyManager
Returns a List identifying the DataOwner for each buddy group for which this node serves as a backup node.
getBackupFqn(Address, Fqn) - Static method in class org.jboss.cache.buddyreplication.BuddyManager
Utility method that retrieves a buddy backup Fqn given the actual Fqn of some data and the data owner's Address.
getBackupFqn(String, Fqn) - Static method in class org.jboss.cache.buddyreplication.BuddyManager
Utility method that retrieves a buddy backup Fqn given the actual Fqn of some data and the buddy group name.
getBackupFqn(Fqn, Fqn) - Static method in class org.jboss.cache.buddyreplication.BuddyManager
Utility method that retrieves a buddy backup Fqn given the actual Fqn of some data and the backup subtree for the buddy group in question
getBackupFqn(Fqn) - Method in class org.jboss.cache.buddyreplication.BuddyManager
Assumes the backup Fqn if the current instance is the data owner
getBatchSize() - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
getBindAddress() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
getBindAddress() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
getBuddies() - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
getBuddyAddresses() - Method in class org.jboss.cache.buddyreplication.BuddyManager
Returns a list of buddies for which this instance is Data Owner.
getBuddyBackupFqn() - Method in class org.jboss.cache.buddyreplication.GravitateResult
 
getBuddyCommunicationTimeout() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
getBuddyCommunicationTimeout() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
getBuddyGroup() - Method in class org.jboss.cache.config.RuntimeConfig
 
getBuddyGroup() - Method in interface org.jboss.cache.notifications.event.BuddyGroupChangedEvent
 
getBuddyGroup() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getBuddyLocatorClass() - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
getBuddyLocatorClass() - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
getBuddyLocatorConfig() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
getBuddyLocatorProperties() - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
getBuddyManager() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current BuddyManager instance associated with the current Cache instance.
getBuddyManager() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getBuddyPoolName() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
getBuddyPoolName() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
getBuddyReplicationConfig() - Method in class org.jboss.cache.config.Configuration
 
getBuddyReplicationConfig() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getBuddyReplicationConfig() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Retrieves the buddy replication configuration element
getBytes() - Method in class org.jboss.cache.marshall.io.ReusableObjectOutputStream
 
getCache(String, boolean) - Method in interface org.jboss.cache.CacheManager
Get a cache configured according to the given configuration name, optionally instantiating the cache if it hasn't already been instantiated.
getCache(String, boolean) - Method in class org.jboss.cache.CacheManagerImpl
 
getCache() - Method in class org.jboss.cache.eviction.BaseEvictionPolicy
 
getCache() - Method in interface org.jboss.cache.eviction.EvictionPolicy
 
getCache() - Method in class org.jboss.cache.eviction.NullEvictionPolicy
 
getCache() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getCache() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getCache() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Retrieves a reference to the underlying Cache
getCache() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
getCache() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
getCache() - Method in interface org.jboss.cache.NodeSPI
Retrieves a reference to the cache in which this Node resides.
getCache() - Method in interface org.jboss.cache.notifications.event.Event
 
getCache() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getCache() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getCache() - Method in class org.jboss.cache.RegionManager
 
getCache() - Method in interface org.jboss.cache.TreeCacheViewMBean
 
getCache() - Method in class org.jboss.cache.UnversionedNode
 
getCacheConfiguration() - Method in interface org.jboss.cache.Region
 
getCacheConfiguration() - Method in class org.jboss.cache.RegionImpl
 
getCacheListeners() - Method in interface org.jboss.cache.Cache
Retrieves an immutable List of objects annotated as CacheListeners attached to the cache.
getCacheListeners(Fqn<?>) - Method in interface org.jboss.cache.Cache
Retrieves an immutable List of objects annotated as CacheListeners attached to a specific region.
getCacheListeners() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getCacheListeners(Fqn) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getCacheListeners() - Method in class org.jboss.cache.notifications.Notifier
 
getCacheLoader() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
Provides the ability to get and set a running cache loader, which, if exists, will be used rather than constructing a new one.
getCacheLoader() - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
getCacheLoader() - Method in class org.jboss.cache.loader.CacheLoaderManager
Returns the cache loader
getCacheLoaderConfig() - Method in class org.jboss.cache.config.Configuration
 
getCacheLoaderConfig() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getCacheLoaderConfig() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Retrieves the cache loader configuration element
getCacheLoaderConfig() - Method in class org.jboss.cache.loader.CacheLoaderManager
Returns the configuration element of the cache loaders
getCacheLoaderConfiguration() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getCacheLoaderConfiguration() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Deprecated. use LegacyConfiguration.getCacheLoaderConfig()
getCacheLoaderLoads() - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
getCacheLoaderLoads() - Method in interface org.jboss.cache.interceptors.CacheLoaderInterceptorMBean
Returns the number of cache loader node loads
getCacheLoaderManager() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current CacheCacheLoaderManager instance associated with the current Cache instance.
getCacheLoaderManager() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getCacheLoaderMisses() - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
getCacheLoaderMisses() - Method in interface org.jboss.cache.interceptors.CacheLoaderInterceptorMBean
Returns the number of cache loader node misses
getCacheLoaderModifications() - Method in class org.jboss.cache.transaction.TransactionEntry
 
getCacheLoaders() - Method in class org.jboss.cache.loader.ChainingCacheLoader
Returns a List of individual cache loaders configured.
getCacheLoaderStores() - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
getCacheLoaderStores() - Method in interface org.jboss.cache.interceptors.CacheStoreInterceptorMBean
Returns the number of cache loader stores
getCacheMode() - Method in class org.jboss.cache.config.Configuration
 
getCacheMode() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getCacheMode() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Returns the current caching mode.
getCacheModeString() - Method in class org.jboss.cache.config.Configuration
 
getCacheNames() - Method in interface org.jboss.cache.CacheManager
Gets the name of all caches that are registered, i.e. that can be by a call to getCache(name, false).
getCacheNames() - Method in class org.jboss.cache.CacheManagerImpl
 
getCacheNodeIdentity() - Method in class org.jboss.cache.marshall.NodeDataExceptionMarker
 
getCacheObjectName() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getCacheService() - Method in interface org.jboss.cache.TreeCacheViewMBean
 
getCacheStatus() - Method in interface org.jboss.cache.Cache
Gets where the cache currently is its lifecycle transitions.
getCacheStatus() - Method in class org.jboss.cache.CacheImpl
 
getCacheStatus() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getCacheStatus() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getCacheStatus() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Gets where this object is in its lifecycle transitions.
getCause() - Method in class org.jboss.cache.marshall.NodeDataExceptionMarker
 
getChanged() - Method in class org.jboss.cache.util.DeltaMap
Returns a Map of the entries changed, not including those removed.
getChannel() - Method in class org.jboss.cache.config.RuntimeConfig
Gets the channel the cache is using.
getChannelFactory() - Method in interface org.jboss.cache.CacheManager
Gets the JGroups ChannelFactory that will be injected into any Configuration that has a multiplexer stack configured.
getChannelFactory() - Method in class org.jboss.cache.CacheManagerImpl
 
getChild(Fqn<?>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChild(Object) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChild(Fqn<?>) - Method in interface org.jboss.cache.Node
Returns the child node
getChild(Object) - Method in interface org.jboss.cache.Node
 
getChild(Object) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Overrides Node.getChild(Object) to return a NodeSPI rather than a Node
getChild(Fqn) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Overrides Node.getChild(Fqn) to return a NodeSPI rather than a Node
getChild(Object) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getChild(Fqn) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getChildDirect(Object) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildDirect(Fqn) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildDirect(Object) - Method in interface org.jboss.cache.NodeSPI
Retrives a child directly by name.
getChildDirect(Fqn) - Method in interface org.jboss.cache.NodeSPI
Retrives a child directly by fully qualified name.
getChildDirect(Fqn) - Method in class org.jboss.cache.UnversionedNode
 
getChildDirect(Object) - Method in class org.jboss.cache.UnversionedNode
 
getChildren() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildren() - Method in interface org.jboss.cache.Node
Returns an immutable set of children nodes.
getChildren() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getChildrenAddedSet() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getChildrenDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildrenDirect(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildrenDirect() - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.getChildren() except that it operates directly on the node and bypasses the interceptor chain.
getChildrenDirect(boolean) - Method in interface org.jboss.cache.NodeSPI
Retrieves children (directly), optionally including any marked as deleted nodes.
getChildrenDirect() - Method in class org.jboss.cache.UnversionedNode
 
getChildrenDirect(boolean) - Method in class org.jboss.cache.UnversionedNode
 
getChildrenMapDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildrenMapDirect() - Method in interface org.jboss.cache.NodeSPI
Returns a map to access the raw children.
getChildrenMapDirect() - Method in class org.jboss.cache.UnversionedNode
 
getChildrenNames(Fqn<E>) - Method in interface org.jboss.cache.CacheSPI
Returns all children of a given node.
getChildrenNames(String) - Method in interface org.jboss.cache.CacheSPI
Convenience method that takes a String representation of an Fqn.
getChildrenNames(Fqn<E>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
Returns all children of a given node.
getChildrenNames(String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getChildrenNames() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Fetches child node names (not pathes).
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Returns an unmodifiable set of relative children names (strings), or returns null if the parent node is not found or if no children are found.
getChildrenNames(Fqn) - Method in interface org.jboss.cache.loader.CacheLoader
Returns a set of children node names.
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Returns a list of children names, all names are relative.
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Returns an unmodifiable set of relative children names, or returns null if the parent node is not found or if no children are found.
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
getChildrenNames() - Method in interface org.jboss.cache.Node
Returns an immutable set of children node names.
getChildrenNames() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getChildrenNamesDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getChildrenNamesDirect() - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.getChildrenNames() except that it operates directly on the node and bypasses the interceptor chain.
getChildrenNamesDirect() - Method in class org.jboss.cache.UnversionedNode
 
getChildrenNamesMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getChildrenNamesMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getChildrenRemovedSet() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getClassLoader() - Method in interface org.jboss.cache.Region
Returns the configured ClassLoader for this region.
getClassLoader() - Method in class org.jboss.cache.RegionImpl
 
getClassName() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
getClusterConfig() - Method in class org.jboss.cache.config.Configuration
 
getClusterConfig() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getClusterConfig() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Gets the JGroups protocol stack config in W3C DOM Element form.
getClusterName() - Method in class org.jboss.cache.CacheImpl
 
getClusterName() - Method in interface org.jboss.cache.CacheSPI
 
getClusterName() - Method in class org.jboss.cache.config.Configuration
 
getClusterName() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getClusterName() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getClusterName() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Get the name of the replication group
getClusterProperties() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getClusterProperties() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Get the cluster properties (e.g. the protocol stack specification in case of JGroups)
getCommits() - Method in class org.jboss.cache.interceptors.TxInterceptor
 
getCommits() - Method in interface org.jboss.cache.interceptors.TxInterceptorMBean
Returns the number of transaction commits
getComponent(Class<T>) - Method in class org.jboss.cache.factories.ComponentRegistry
 
getComponent(String, Class<T>) - Method in class org.jboss.cache.factories.ComponentRegistry
Retrieves a named component which can be assigned to the type passed in.
getComponentRegistry() - Method in class org.jboss.cache.CacheImpl
 
getConfig() - Method in interface org.jboss.cache.buddyreplication.BuddyLocator
Gets the configuration for this BuddyLocator.
getConfig() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
getConfig() - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocator
 
getConfig() - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
 
getConfig() - Method in interface org.jboss.cache.loader.CacheLoader
Gets the configuration.
getConfig() - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.FileCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.JDBCCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated.  
getConfig() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
getConfig() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
getConfig() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
getConfig() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
getConfigResource() - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
getConfigSubElement(Element) - Static method in class org.jboss.cache.xml.XmlHelper
Convenience method, equivalent to calling getSubElement(element, "config");
getConfiguration() - Method in interface org.jboss.cache.Cache
Retrieves the configuration of this cache.
getConfiguration() - Method in class org.jboss.cache.CacheImpl
 
getConfiguration(String) - Method in interface org.jboss.cache.config.ConfigurationRegistry
Gets a clone of the Configuration registered under the given name.
getConfiguration(String) - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
getConfiguration() - Method in class org.jboss.cache.eviction.LRUAlgorithm
 
getConfiguration() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getConfiguration() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getConfiguration() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
getConfigurationNames() - Method in interface org.jboss.cache.CacheManager
Gets the names of all the configurations of which this object is aware.
getConfigurationNames() - Method in class org.jboss.cache.CacheManagerImpl
 
getConfigurationNames() - Method in interface org.jboss.cache.config.ConfigurationRegistry
Gets the names of all registered configurations.
getConfigurationNames() - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
getConfigurationRegistry() - Method in class org.jboss.cache.CacheManagerImpl
 
getConnection() - Method in interface org.jboss.cache.loader.ConnectionFactory
 
getConnection() - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
getConnectionFactoryClass() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getConnections() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
getConnections() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
getContextLockAcquisitionTimeout(long) - Method in class org.jboss.cache.InvocationContext
If the acq timeout if overwritten for current call, then return that one.
getCoordinator() - Method in interface org.jboss.cache.RPCManager
 
getCoordinator() - Method in class org.jboss.cache.RPCManagerImpl
 
getCreateTable() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getCreateTableDDL() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getCreationTimestamp() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
getCreationTimeStamp() - Method in class org.jboss.cache.eviction.NodeEntry
Get the time stamp for when the node entry was created.
getCurrentTransaction() - Method in class org.jboss.cache.CacheImpl
Returns the transaction associated with the current thread.
getCurrentTransaction(boolean) - Method in class org.jboss.cache.CacheImpl
Returns the transaction associated with the thread; optionally creating it if is does not exist.
getCurrentTransaction(Transaction) - Method in class org.jboss.cache.CacheImpl
Returns the global transaction for this local transaction.
getCurrentTransaction(Transaction, boolean) - Method in class org.jboss.cache.CacheImpl
Returns the global transaction for this local transaction.
getCurrentTransaction(Transaction, boolean) - Method in interface org.jboss.cache.CacheSPI
Returns the global transaction for this local transaction.
getCurrentTransaction() - Method in interface org.jboss.cache.CacheSPI
Returns the transaction associated with the current thread.
getCurrentTransaction(Transaction, boolean) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getCurrentTransaction() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getCustomMarshallerVersionInt() - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
getData(Fqn<?>) - Method in interface org.jboss.cache.Cache
Retrieves a defensively copied data map of the underlying node.
getData(Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
Retrieves a defensively copied data map of the underlying node.
getData() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getData() - Method in class org.jboss.cache.Modification
Returns the modification Map set.
getData() - Method in interface org.jboss.cache.Node
Returns a map containing the data in this Node.
getData() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getData() - Method in interface org.jboss.cache.notifications.event.NodeActivatedEvent
 
getData() - Method in interface org.jboss.cache.notifications.event.NodeLoadedEvent
 
getData() - Method in interface org.jboss.cache.notifications.event.NodeModifiedEvent
When called with isPre() == true, this is the initial state of the Node before modification.
getData() - Method in interface org.jboss.cache.notifications.event.NodePassivatedEvent
 
getData() - Method in interface org.jboss.cache.notifications.event.NodeRemovedEvent
 
getData() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getDataDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getDataDirect() - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.getData() except that it operates directly on the node and bypasses the interceptor chain.
getDataDirect() - Method in class org.jboss.cache.UnversionedNode
 
getDataMapMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getDataMapMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getDataOwner() - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
getDataSource() - Method in class org.jboss.cache.loader.C3p0ConnectionFactory
 
getDatasourceName() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getDataVersion() - Method in class org.jboss.cache.config.Option
 
getDefaultCacheObjectName(Cache) - Static method in class org.jboss.cache.jmx.JmxUtil
 
getDefaultCacheObjectName(Configuration, String) - Static method in class org.jboss.cache.jmx.JmxUtil
 
getDefaultClusterConfig() - Method in class org.jboss.cache.config.Configuration
Returns a URL to a default JGroups configuration file.
getDefaultEventQueueSize() - Method in class org.jboss.cache.config.EvictionConfig
 
getDefaultEvictionPolicyClass() - Method in class org.jboss.cache.config.EvictionConfig
 
getDelegate() - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
getDelegate() - Method in class org.jboss.cache.UnversionedNode
 
getDelegationTarget() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getDelegationTarget() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getDeleteAllSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getDeleteNodeSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getDeleteNodeSql() - Method in class org.jboss.cache.loader.JDBCCacheLoaderConfig
Returns the sql string for removing a node and all its children.
getDirect(K) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getDirect(K) - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.get(Object) except that it operates directly on the node and bypasses the interceptor chain.
getDirect(Object) - Method in class org.jboss.cache.UnversionedNode
 
getDocumentRoot(InputStream) - Static method in class org.jboss.cache.xml.XmlHelper
Returns the root element of a given input stream
getDriverClass() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getDriverName(Connection) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
getDropTable() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getDropTableDDL() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getDummyNodesCreatedByCacheLoader() - Method in class org.jboss.cache.transaction.TransactionEntry
 
getElapsedTime() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getElapsedTime() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns seconds since cache started
getElementContent(Element, boolean) - Static method in class org.jboss.cache.xml.XmlHelper
Reads the contents of the element passed in.
getElementDifference() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
getEnvironment() - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the environment in effect for this context.
getErroneousAttributes() - Method in exception org.jboss.cache.config.ConfigurationException
 
getEventQueueSize() - Method in class org.jboss.cache.config.EvictionRegionConfig
 
getEventType() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.ElementSizePolicy
 
getEvictionAlgorithm() - Method in interface org.jboss.cache.eviction.EvictionPolicy
Get the associated EvictionAlgorithm used by the EvictionPolicy.
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.ExpirationPolicy
 
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.FIFOPolicy
 
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.LFUPolicy
 
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.LRUPolicy
 
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.MRUPolicy
 
getEvictionAlgorithm() - Method in class org.jboss.cache.eviction.NullEvictionPolicy
Returns NullEvictionAlgorithm.INSTANCE.
getEvictionConfig() - Method in class org.jboss.cache.config.Configuration
 
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.ElementSizePolicy
 
getEvictionConfigurationClass() - Method in interface org.jboss.cache.eviction.EvictionPolicy
The EvictionPolicyConfig implementation class used by this EvictionPolicy.
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.ExpirationPolicy
 
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.FIFOPolicy
 
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.LFUPolicy
 
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.LRUPolicy
 
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.MRUPolicy
 
getEvictionConfigurationClass() - Method in class org.jboss.cache.eviction.NullEvictionPolicy
Returns NullEvictionPolicyConfig.
getEvictionPolicy() - Method in interface org.jboss.cache.Region
Returns an eviction policy.
getEvictionPolicy() - Method in class org.jboss.cache.RegionImpl
 
getEvictionPolicyClass() - Method in interface org.jboss.cache.config.EvictionPolicyConfig
Gets the class name of the EvictionPolicy implementation this object will configure.
getEvictionPolicyClass() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
getEvictionPolicyClass() - Method in class org.jboss.cache.eviction.NullEvictionPolicyConfig
Returns NullEvictionPolicy.
getEvictionPolicyConfig() - Method in class org.jboss.cache.config.EvictionRegionConfig
 
getEvictionPolicyConfig() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getEvictionPolicyConfig() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getEvictionPolicyConfig() - Method in interface org.jboss.cache.Region
Returns an eviction policy configuration.
getEvictionPolicyConfig() - Method in class org.jboss.cache.RegionImpl
 
getEvictionQueue() - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Get the underlying EvictionQueue implementation.
getEvictionQueue() - Method in interface org.jboss.cache.eviction.EvictionAlgorithm
Get the EvictionQueue implementation used by this algorithm.
getEvictionQueue() - Method in class org.jboss.cache.eviction.NullEvictionAlgorithm
Returns NullEvictionQueue.INSTANCE.
getEvictionRegionConfig() - Method in interface org.jboss.cache.Region
Returns an eviction region configuration for this region.
getEvictionRegionConfig() - Method in class org.jboss.cache.RegionImpl
 
getEvictionRegionConfigs() - Method in class org.jboss.cache.config.EvictionConfig
 
getEvictions() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getEvictions() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns the number of cache eviction operations
getEvictionTimerTask() - Method in class org.jboss.cache.RegionManager
 
getExpirationKeyName() - Method in class org.jboss.cache.eviction.ExpirationConfiguration
Returns the expirationKeyName.
getExposeManagementStatistics() - Method in class org.jboss.cache.config.Configuration
 
getExposeManagementStatistics() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getExposeManagementStatistics() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Gets whether the cache should create interceptor mbeans that are used to capture and publish interceptor statistics.
getFactory(Class) - Method in class org.jboss.cache.factories.ComponentRegistry
Retrieves a component factory instance capable of constructing components of a specified type.
getFactory() - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
getFetchInMemoryState() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getFetchInMemoryState() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Returns whether or not any initial state transfer or subsequent partial state transfer following an activateRegion call should include in-memory state.
getFirstCacheLoaderConfig() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
getFirstLRUNodeEntry() - Method in class org.jboss.cache.eviction.LRUQueue
 
getFirstMaxAgeNodeEntry() - Method in class org.jboss.cache.eviction.LRUQueue
 
getFirstNodeEntry() - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
getFirstNodeEntry() - Method in interface org.jboss.cache.eviction.EvictionQueue
Get the first entry in the queue.
getFirstNodeEntry() - Method in class org.jboss.cache.eviction.FIFOQueue
 
getFirstNodeEntry() - Method in class org.jboss.cache.eviction.LFUQueue
Return the first node to evict.
getFirstNodeEntry() - Method in class org.jboss.cache.eviction.LRUQueue
 
getFirstNodeEntry() - Method in class org.jboss.cache.eviction.MRUQueue
Will return the first entry in the nodeMap.
getFirstNodeEntry() - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns null
getForceDataGravitation() - Method in class org.jboss.cache.config.Option
 
getFqn() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
getFqn() - Method in class org.jboss.cache.eviction.NodeEntry
 
getFqn() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getFqn() - Method in class org.jboss.cache.lock.IdentityLock
Returns the FQN this lock, may be null.
getFqn() - Method in interface org.jboss.cache.lock.NodeLock
 
getFqn() - Method in class org.jboss.cache.marshall.NodeData
 
getFqn() - Method in class org.jboss.cache.Modification
Returns the modification fqn.
getFqn() - Method in interface org.jboss.cache.Node
Returns the Fqn which represents the location of this Node in the cache structure.
getFqn() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getFqn() - Method in interface org.jboss.cache.notifications.event.NodeEvent
 
getFqn() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getFqn() - Method in interface org.jboss.cache.Region
Returns the Fqn of this region.
getFqn() - Method in class org.jboss.cache.RegionImpl
 
getFqn() - Method in class org.jboss.cache.UnversionedNode
Returns the name of this node.
getFqn2() - Method in class org.jboss.cache.Modification
 
getGlobalTransaction(InvocationContext) - Method in class org.jboss.cache.interceptors.OptimisticInterceptor
 
getGlobalTransaction() - Method in class org.jboss.cache.InvocationContext
Retrieves the global transaction associated with this invocation
getGroupName() - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
getGroupNameFromAddress(Object) - Static method in class org.jboss.cache.buddyreplication.BuddyManager
 
getGroupRequestMode() - Method in class org.jboss.cache.config.Option
 
getHitMissRatio() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getHitMissRatio() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns the hit/miss ratio for the cache This ratio is defined as hits/(hits + misses)
getHits() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getHits() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns the number of cache attribute hits
getHost() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
getId() - Method in class org.jboss.cache.marshall.MethodCall
 
getId() - Method in class org.jboss.cache.transaction.GlobalTransaction
 
getIndividualCacheLoaderConfigs() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
getInitialContext(Hashtable) - Method in class org.jboss.cache.transaction.DummyContextFactory
Creates an Initial Context for beginning name resolution.
getInitialStateRetrievalTimeout() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Deprecated. 
getInitialStateRetrievalTimeout() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Deprecated. use LegacyConfiguration.getStateRetrievalTimeout()
getInputStream(byte[]) - Method in class org.jboss.cache.marshall.io.ObjectStreamPool
 
getInsertNodeSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getInstance() - Static method in class org.jboss.cache.DefaultCacheFactory
Deprecated. 
getInstance() - Static method in class org.jboss.cache.factories.InterceptorChainFactory
Deprecated. 
getInstance(ComponentRegistry, Configuration) - Static method in class org.jboss.cache.factories.InterceptorChainFactory
 
getInstance() - Static method in class org.jboss.cache.transaction.BatchModeTransactionManager
 
getInstance() - Static method in class org.jboss.cache.transaction.DummyTransactionManager
 
getInterceptorChain() - Method in class org.jboss.cache.CacheImpl
 
getInterceptorChain() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current Interceptor chain.
getInterceptorChain() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getInternalFqns() - Method in class org.jboss.cache.CacheImpl
Returns a Set of Fqns of the topmost node of internal regions that should not included in standard state transfers.
getInternalFqns() - Method in interface org.jboss.cache.CacheSPI
Returns a Set of Fqns of the topmost node of internal regions that should not included in standard state transfers.
getInternalFqns() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getInternalState(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getInternalState(boolean) - Method in interface org.jboss.cache.NodeSPI
Very similar to NodeSPI.getDataDirect(), except that this method may also encode some internal data as attributes in the map, using special _JBOSS_INTERNAL_XXX Strings as keys.
getInternalState(boolean) - Method in class org.jboss.cache.UnversionedNode
 
getInternalState(boolean) - Method in class org.jboss.cache.VersionedNode
 
getInUseTimeout() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
getInUseTimeoutTimestamp() - Method in class org.jboss.cache.eviction.NodeEntry
 
getInvalidations() - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
getInvalidations() - Method in interface org.jboss.cache.interceptors.InvalidationInterceptorMBean
Returns the number of cache invalidations
getInvocationContext() - Method in interface org.jboss.cache.Cache
 
getInvocationContext() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getInvocationLocksAcquired() - Method in class org.jboss.cache.InvocationContext
 
getIsolationLevel() - Method in class org.jboss.cache.config.Configuration
 
getIsolationLevel() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getIsolationLevel() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Returns the transaction isolation level.
getIsolationLevelString() - Method in class org.jboss.cache.config.Configuration
 
getJdbcPassword() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getJdbcURL() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getJdbcUser() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getKey() - Method in class org.jboss.cache.Modification
Returns the modification key.
getKeys(String) - Method in interface org.jboss.cache.Cache
Convenience method that takes in a String represenation of the Fqn.
getKeys(Fqn<?>) - Method in interface org.jboss.cache.Cache
Returns a set of attribute keys for the Fqn.
getKeys(String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
Returns a set of attribute keys for the Fqn.
getKeys(Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
Returns a set of attribute keys for the Fqn.
getKeys() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getKeys() - Method in interface org.jboss.cache.Node
Returns a Set containing the data in this Node.
getKeys() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getKeysDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getKeysDirect() - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.getKeys() except that it operates directly on the node and bypasses the interceptor chain.
getKeysDirect() - Method in class org.jboss.cache.UnversionedNode
 
getKeysMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getKeysMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getKeyValueMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getKeyValueMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getLast() - Method in class org.jboss.cache.interceptors.Interceptor
 
getLastElement() - Method in class org.jboss.cache.Fqn
 
getLastElementAsString() - Method in class org.jboss.cache.Fqn
If this is the root, returns Fqn.SEPARATOR.
getLastModified() - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
getLength() - Static method in class org.jboss.cache.Version
 
getLocalAddress() - Method in interface org.jboss.cache.Cache
Returns the local address of this cache in a cluster, or null if running in local mode.
getLocalAddress() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getLocalAddress() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getLocalAddress() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Returns the local address of this cache in a cluster, or null if running in local mode.
getLocalAddress() - Method in interface org.jboss.cache.RPCManager
Retrieves the local JGroups channel's address
getLocalAddress() - Method in class org.jboss.cache.RPCManagerImpl
 
getLocalTransaction() - Method in class org.jboss.cache.CacheImpl
Returns the transaction associated with the current thread.
getLocalTransaction(GlobalTransaction) - Method in class org.jboss.cache.transaction.TransactionTable
Returns the local transaction associated with a GlobalTransaction.
getLocation() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
getLocation() - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
getLocation() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
getLock() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getLock() - Method in interface org.jboss.cache.NodeSPI
Returns a lock for this node.
getLock() - Method in class org.jboss.cache.UnversionedNode
 
getLockAcquisitionTimeout() - Method in class org.jboss.cache.config.Configuration
 
getLockAcquisitionTimeout() - Method in class org.jboss.cache.config.Option
Gets any lock acquisition timeout configured for the call.
getLockAcquisitionTimeout() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getLockAcquisitionTimeout() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Default max time to wait for a lock.
getLockMap() - Method in class org.jboss.cache.lock.IdentityLock
 
getLocks() - Method in class org.jboss.cache.transaction.TransactionEntry
Returns the locks in use.
getLockStrategy() - Static method in class org.jboss.cache.lock.LockStrategyFactory
 
getLockStrategy(IsolationLevel) - Static method in class org.jboss.cache.lock.LockStrategyFactory
 
getLogger() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
getLogger() - Method in class org.jboss.cache.loader.JDBCCacheLoader
 
getLogger() - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated.  
getMarshaller() - Method in interface org.jboss.cache.CacheSPI
Retrieves an instance of a Marshaller, which is capable of converting Java objects to bytestreams and back in an efficient manner, which is also interoperable with bytestreams produced/consumed by other versions of JBoss Cache.
getMarshaller() - Method in class org.jboss.cache.config.Configuration
 
getMarshaller() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getMarshaller() - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
getMarshallerClass() - Method in class org.jboss.cache.config.Configuration
 
getMaxAgeSeconds() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
getMaxDoublingSize() - Method in class org.jboss.cache.util.ExposedByteArrayOutputStream
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxElementsPerNode() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
getMaxNodes() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
getMBeanElement(Element) - Method in class org.jboss.cache.factories.XmlConfigurationParser
 
getMBeanServer() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getMembers() - Method in interface org.jboss.cache.Cache
Returns a list of members in the cluster, or null if running in local mode.
getMembers() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getMembers() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getMembers() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Returns a list of members in the cluster, or null if running in local mode.
getMembers() - Method in interface org.jboss.cache.RPCManager
Returns a defensively copied list of members in the current cluster view.
getMembers() - Method in class org.jboss.cache.RPCManagerImpl
 
getMergedChildren() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Returns 2 Sets - a set of children added (first set) and a set of children removed.
getMergedChildren() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getMergedData() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Attempts to merge data changed during the current transaction with the data in the underlying tree.
getMergedData() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getMethod() - Method in class org.jboss.cache.util.reflect.CachedMethod
 
getMethodCall() - Method in class org.jboss.cache.InvocationContext
 
getMethodId() - Method in class org.jboss.cache.marshall.MethodCall
 
getMinNodes() - Method in class org.jboss.cache.eviction.LFUConfiguration
 
getMinTimeToLiveSeconds() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
getMisses() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getMisses() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns the number of cache attribute misses
getModifications() - Method in class org.jboss.cache.transaction.TransactionEntry
Returns all modifications.
getModificationType() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getModificationType() - Method in interface org.jboss.cache.notifications.event.NodeModifiedEvent
 
getModifiedTimeStamp() - Method in class org.jboss.cache.eviction.NodeEntry
Get modified time stamp.
getMultiplexerService() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getMultiplexerService() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getMultiplexerStack() - Method in class org.jboss.cache.config.Configuration
 
getMultiplexerStack() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getMultiplexerStack() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Retrieves the JGroups multiplexer stack name if defined.
getMuxChannelFactory() - Method in class org.jboss.cache.config.RuntimeConfig
Gets the factory the cache will use to create a multiplexed channel.
getMuxChannelFactory() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getMuxChannelFactory() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getNameInNamespace() - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the full name of this context within its own namespace.
getNameParser(Name) - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the parser associated with the named context.
getNameParser(String) - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the parser associated with the named context.
getNewBufferSize(int, int) - Method in class org.jboss.cache.util.ExposedByteArrayOutputStream
Gets the number of bytes to which the internal buffer should be resized.
getNewView() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getNewView() - Method in interface org.jboss.cache.notifications.event.ViewChangedEvent
 
getNext() - Method in class org.jboss.cache.interceptors.Interceptor
 
getNextNotificationSequenceNumber() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getNextNotificationSequenceNumber() - Method in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
Gets the sequence number for the next notification.
getNode(Fqn<?>) - Method in interface org.jboss.cache.Cache
A convenience method to retrieve a node directly from the cache.
getNode(String) - Method in interface org.jboss.cache.Cache
Convenience method that takes a string representation of an Fqn.
getNode(String) - Method in interface org.jboss.cache.CacheSPI
Overrides Cache.getNode(String) to return a NodeSPI instead of a Node.
getNode(Fqn<?>) - Method in interface org.jboss.cache.CacheSPI
Overrides Cache.getNode(Fqn) to return a NodeSPI instead of a Node.
getNode(Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getNode(String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getNode() - Method in class org.jboss.cache.lock.IdentityLock
Returns the node for this lock, may be null.
getNode(Fqn) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
 
getNode(Fqn) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
getNode() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Retrieves a reference to the underlying NodeSPI instance.
getNode() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getNodeCount() - Method in class org.jboss.cache.loader.JDBCCacheLoader
Returns a number representing the count of persisted children.
getNodeCountSql() - Method in class org.jboss.cache.loader.JDBCCacheLoaderConfig
Returns an sql that will count all the persisted node.
getNodeData() - Method in class org.jboss.cache.buddyreplication.GravitateResult
 
getNodeDataList(Fqn, List<NodeData>) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
getNodeDataList(Fqn, List<NodeData>) - Method in class org.jboss.cache.loader.JDBCCacheLoader
Subscribes to contract.
getNodeEntry(Fqn) - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
getNodeEntry(String) - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
getNodeEntry(Fqn) - Method in interface org.jboss.cache.eviction.EvictionQueue
Retrieve a node entry by Fqn.
getNodeEntry(String) - Method in interface org.jboss.cache.eviction.EvictionQueue
 
getNodeEntry(Fqn) - Method in class org.jboss.cache.eviction.FIFOQueue
 
getNodeEntry(String) - Method in class org.jboss.cache.eviction.FIFOQueue
 
getNodeEntry(Fqn) - Method in class org.jboss.cache.eviction.LFUQueue
 
getNodeEntry(String) - Method in class org.jboss.cache.eviction.LFUQueue
 
getNodeEntry(Fqn) - Method in class org.jboss.cache.eviction.LRUQueue
 
getNodeEntry(String) - Method in class org.jboss.cache.eviction.LRUQueue
 
getNodeEntry(Fqn) - Method in class org.jboss.cache.eviction.MRUQueue
 
getNodeEntry(String) - Method in class org.jboss.cache.eviction.MRUQueue
 
getNodeEntry(Fqn) - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns null
getNodeEntry(String) - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns null
getNodeFactory() - Method in class org.jboss.cache.config.RuntimeConfig
 
getNodeLockingScheme() - Method in class org.jboss.cache.config.Configuration
 
getNodeLockingScheme() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getNodeLockingScheme() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getNodeLockingSchemeString() - Method in class org.jboss.cache.config.Configuration
 
getNodeMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getNodeMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getNodes() - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
 
getNodes() - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
Returns the nodes.
getNodesAfter(Fqn) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
Returns all nodes equal to or after the given node.
getNodesAfter(Fqn) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
getNodeSPI() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getNodeType() - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
getNodeVersion(TransactionWorkspace, Fqn) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
getNotificationInfo() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getNotificationInfo() - Static method in class org.jboss.cache.jmx.CacheNotificationListener
 
getNotificationServiceName() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getNotifier() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current Notifier instance associated with the current Cache instance.
getNotifier() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getNumberOfAttributes() - Method in class org.jboss.cache.CacheImpl
Returns an approximation of the total number of attributes in the cache.
getNumberOfAttributes(Fqn) - Method in class org.jboss.cache.CacheImpl
Returns an approximation of the total number of attributes in this sub cache.
getNumberOfAttributes() - Method in interface org.jboss.cache.CacheSPI
 
getNumberOfAttributes() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getNumberOfAttributes() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
 
getNumberOfAttributes() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getNumberOfAttributes() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getNumberOfAttributes() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
getNumberOfElements() - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
getNumberOfElements() - Method in interface org.jboss.cache.eviction.EvictionQueue
Get the number of elements in the queue.
getNumberOfElements() - Method in class org.jboss.cache.eviction.FIFOQueue
 
getNumberOfElements() - Method in class org.jboss.cache.eviction.LFUQueue
 
getNumberOfElements() - Method in class org.jboss.cache.eviction.LRUQueue
 
getNumberOfElements() - Method in class org.jboss.cache.eviction.MRUQueue
 
getNumberOfElements() - Method in class org.jboss.cache.eviction.NodeEntry
 
getNumberOfElements() - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns 0
getNumberOfLocksHeld() - Method in class org.jboss.cache.CacheImpl
Returns the number of read or write locks held across the entire cache.
getNumberOfLocksHeld() - Method in interface org.jboss.cache.CacheSPI
 
getNumberOfLocksHeld() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getNumberOfNodes() - Method in class org.jboss.cache.CacheImpl
Returns an approximation of the total number of nodes in the cache.
getNumberOfNodes() - Method in interface org.jboss.cache.CacheSPI
 
getNumberOfNodes() - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
getNumberOfNodes() - Method in interface org.jboss.cache.eviction.EvictionQueue
Get the number of nodes in the queue.
getNumberOfNodes() - Method in class org.jboss.cache.eviction.FIFOQueue
 
getNumberOfNodes() - Method in class org.jboss.cache.eviction.LFUQueue
 
getNumberOfNodes() - Method in class org.jboss.cache.eviction.LRUQueue
 
getNumberOfNodes() - Method in class org.jboss.cache.eviction.MRUQueue
 
getNumberOfNodes() - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns 0
getNumberOfNodes() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getNumberOfNodes() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
 
getNumberOfNodes() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getNumberOfNodes() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getNumberOfNodes() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
getNumberOfNodeVisits() - Method in class org.jboss.cache.eviction.NodeEntry
 
getNumBuddies() - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
getNumGlobalTransactions() - Method in class org.jboss.cache.transaction.TransactionTable
Returns the number of global transactions.
getNumLocalTransactions() - Method in class org.jboss.cache.transaction.TransactionTable
Returns the number of local transactions.
getObjectInputStreamPoolSize() - Method in class org.jboss.cache.config.Configuration
 
getObjectOutputStreamPoolSize() - Method in class org.jboss.cache.config.Configuration
 
getOldValue() - Method in class org.jboss.cache.Modification
Returns the post modification old value.
getOption() - Method in class org.jboss.cache.transaction.TransactionEntry
Retrieves a transaction scope option override
getOptionOverrides() - Method in class org.jboss.cache.InvocationContext
Retrieves the option overrides associated with this invocation
getOrCreateChild(Object, GlobalTransaction) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getOrCreateChild(Object, GlobalTransaction) - Method in interface org.jboss.cache.NodeSPI
Returns an existing child or creates a new one using a global transaction.
getOrCreateChild(Object, GlobalTransaction, boolean) - Method in class org.jboss.cache.UnversionedNode
 
getOrCreateComponent(Class<T>) - Method in class org.jboss.cache.factories.ComponentRegistry
Retrieves a named component if one exists, and if not, attempts to find a factory capable of constructing the component (factories annotated with the DefaultFactoryFor annotation that is capable of creating the component class).
getOrCreateComponent(String, Class<T>) - Method in class org.jboss.cache.factories.ComponentRegistry
Retrieves a named component if one exists, and if not, attempts to find a factory capable of constructing the component (factories annotated with the DefaultFactoryFor annotation that is capable of creating the component class).
getOrderedSynchronizationHandler() - Method in class org.jboss.cache.transaction.TransactionEntry
 
getOriginal() - Method in class org.jboss.cache.util.DeltaMap
Returns the original wrapped Map.
getOutputStream() - Method in class org.jboss.cache.marshall.io.ObjectStreamPool
 
getOverallState() - Method in class org.jboss.cache.factories.ComponentRegistry
 
getOwnerForLock() - Method in class org.jboss.cache.CacheImpl
Returns an object suitable for use in node locking, either the current transaction or the current thread if there is no transaction.
getParameterAnnotations() - Method in class org.jboss.cache.util.reflect.CachedMethod
 
getParameterTypes() - Method in class org.jboss.cache.util.reflect.CachedMethod
 
getParent() - Method in class org.jboss.cache.Fqn
Returns the parent of this Fqn.
getParent() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getParent() - Method in interface org.jboss.cache.Node
Returns the parent node.
getParent() - Method in interface org.jboss.cache.NodeSPI
Returns the parent node as a NodeSPI, instead of Node from Node.getParent(), and is otherwise identical.
getParent() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getParent() - Method in class org.jboss.cache.UnversionedNode
Returns a parent by checking the TreeMap by name.
getParent() - Method in class org.jboss.cache.VersionedNode
Returns the parent.
getPartialStateMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
getPassivations() - Method in class org.jboss.cache.interceptors.PassivationInterceptor
 
getPassivations() - Method in interface org.jboss.cache.interceptors.PassivationInterceptorMBean
Returns the number of cache node passivations
getPort() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
getPort() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
getPort() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
getPreload() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
getPrepares() - Method in class org.jboss.cache.interceptors.TxInterceptor
 
getPrepares() - Method in interface org.jboss.cache.interceptors.TxInterceptorMBean
Returns the number of transaction prepares
getProperties() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
getPushStateFuture() - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Returns the Future instance of a running in-memory to cache loader push task.
getPushStateWhenCoordinatorTimeout() - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
getQueueSize() - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
getRawBuffer() - Method in class org.jboss.cache.util.ExposedByteArrayOutputStream
Gets the internal buffer array.
getRawVersion() - Method in class org.jboss.cache.optimistic.DefaultDataVersion
 
getReaderOwners() - Method in class org.jboss.cache.lock.IdentityLock
Return a copy of the reader lock owner in List.
getReaderOwners() - Method in interface org.jboss.cache.lock.NodeLock
Returns a copy of the reader lock owner in List.
getReadWriteRatio() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getReadWriteRatio() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns the read/write ratio for the cache This ratio is defined as (hits + misses)/stores
getReconnectWaitTime() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
getRecursiveChildrenSql() - Method in class org.jboss.cache.loader.JDBCCacheLoaderConfig
Returns an sql that will return a node and all its children.
getReferencedObject(int) - Method in class org.jboss.cache.marshall.UnmarshalledReferences
Retrieves an object referenced by an id
getRegion(Fqn<?>, boolean) - Method in interface org.jboss.cache.Cache
Retrieves a Region for a given Fqn.
getRegion(Fqn<?>, boolean) - Method in class org.jboss.cache.CacheImpl
 
getRegion(Fqn, boolean) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getRegion(Fqn) - Method in class org.jboss.cache.marshall.AbstractMarshaller
Retrieves the Region from the RegionManager after taking into account that this may be a Buddy Backup Fqn.
getRegion(Fqn, boolean) - Method in class org.jboss.cache.RegionManager
Returns a region by Fqn, creating it optionally if absent.
getRegion(Fqn, Region.Type, boolean) - Method in class org.jboss.cache.RegionManager
An overloaded form of RegionManager.getRegion(Fqn,boolean) that takes an additional Region.Type parameter to force regions of a specific type.
getRegion(String, boolean) - Method in class org.jboss.cache.RegionManager
Returns a region using Fqn.fromString(fqn), calling RegionManager.getRegion(Fqn,boolean)
getRegionFqn() - Method in class org.jboss.cache.config.EvictionRegionConfig
 
getRegionManager() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current RegionManager instance associated with the current Cache instance.
getRegionManager() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getRegionName() - Method in class org.jboss.cache.config.EvictionRegionConfig
 
getRegisterInterceptors() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getRegisterInterceptors() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Gets whether this object should register the cache's interceptors with JMX during {@link #create()}.
getRemoved() - Method in class org.jboss.cache.util.DeltaMap
Returns the entries removed, including entries excluded by the constructor.
getRemovedNodes() - Method in class org.jboss.cache.transaction.TransactionEntry
Gets the list of removed nodes.
getReplicationVersion() - Method in class org.jboss.cache.config.Configuration
 
getReplicationVersion() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getReplicationVersion() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Gets the format version of the data transferred during an initial state transfer or a call to Region.activate().
getReplQueueInterval() - Method in class org.jboss.cache.config.Configuration
 
getReplQueueInterval() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getReplQueueInterval() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getReplQueueMaxElements() - Method in class org.jboss.cache.config.Configuration
 
getReplQueueMaxElements() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getReplQueueMaxElements() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getReplVersionString() - Method in class org.jboss.cache.config.Configuration
 
getReturnOld() - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
getRollbacks() - Method in class org.jboss.cache.interceptors.TxInterceptor
 
getRollbacks() - Method in interface org.jboss.cache.interceptors.TxInterceptorMBean
Returns the number of transaction rollbacks
getRoot() - Method in interface org.jboss.cache.Cache
Returns the root node of this cache.
getRoot() - Method in class org.jboss.cache.CacheImpl
Returns the root node.
getRoot() - Method in interface org.jboss.cache.CacheSPI
Overrides Cache.getRoot() to return a NodeSPI instead of a Node.
getRoot() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getRPCManager() - Method in class org.jboss.cache.CacheImpl
 
getRPCManager() - Method in interface org.jboss.cache.CacheSPI
Gets a handle of the RPC manager.
getRPCManager() - Method in class org.jboss.cache.config.RuntimeConfig
 
getRPCManager() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getRuntimeConfig() - Method in class org.jboss.cache.config.Configuration
 
getSelectChildFqnsSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getSelectChildNamesSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getSelectNodeSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getServiceName() - Method in class org.jboss.cache.jmx.CacheNotificationListener
 
getShutdownHookBehavior() - Method in class org.jboss.cache.config.Configuration
 
getSingletonStoreClass() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
getSingletonStoreClass() - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
getSingletonStoreConfig() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
getSingletonStoreDefaultConfig() - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Returns SingletonStoreCacheLoader's configuration instance.
getSingletonStoreproperties() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
getSize() - Method in class org.jboss.cache.loader.ChainingCacheLoader
Returns the number of cache loaders in the chain.
getState() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getState() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Legacy attribute to expose the cache status in terms of the JBoss AS ServiceMBean values.
getState() - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
getState(String) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
getState(OutputStream) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
getState(String, OutputStream) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
getState(ObjectOutputStream, Fqn, long, boolean, boolean) - Method in class org.jboss.cache.statetransfer.StateTransferManager
Writes the state for the portion of the tree named by fqn to the provided OutputStream.
getStateRetrievalTimeout() - Method in class org.jboss.cache.config.Configuration
 
getStateRetrievalTimeout() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getStateRetrievalTimeout() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Get the max time to wait until the state is retrieved.
getStateTransferGenerator(CacheSPI) - Static method in class org.jboss.cache.statetransfer.StateTransferFactory
Gets the StateTransferGenerator able to handle the given cache instance.
getStateTransferGenerator() - Method in class org.jboss.cache.statetransfer.StateTransferManager
 
getStateTransferIntegrator(ObjectInputStream, Fqn, CacheSPI) - Static method in class org.jboss.cache.statetransfer.StateTransferFactory
 
getStateTransferIntegrator(ObjectInputStream, Fqn) - Method in class org.jboss.cache.statetransfer.StateTransferManager
 
getStateTransferManager() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current StateTransferManager instance associated with the current Cache instance.
getStateTransferManager() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getStatisticsEnabled() - Method in class org.jboss.cache.interceptors.Interceptor
 
getStatisticsEnabled() - Method in interface org.jboss.cache.interceptors.InterceptorMBean
Returns whether an interceptor's statistics are being captured.
getStatus() - Method in interface org.jboss.cache.Region
 
getStatus() - Method in class org.jboss.cache.RegionImpl
 
getStatus() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Get the status of the transaction associated with the calling thread.
getStatus() - Method in class org.jboss.cache.transaction.DummyTransaction
Get the status of the transaction.
getStatus() - Method in class org.jboss.cache.transaction.DummyUserTransaction
Get the status of the transaction.
getStores() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getStores() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns the number of cache attribute put operations
getSubElement(Element, String) - Static method in class org.jboss.cache.xml.XmlHelper
Returns a named sub-element of the current element passed in.
getSubFqn(int, int) - Method in class org.jboss.cache.Fqn
Obtains a sub-Fqn from the given Fqn.
getSyncCommitPhase() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getSyncCommitPhase() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getSyncReplTimeout() - Method in class org.jboss.cache.config.Configuration
 
getSyncReplTimeout() - Method in class org.jboss.cache.config.Option
 
getSyncReplTimeout() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getSyncReplTimeout() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Returns the default max timeout after which synchronous replication calls return.
getSyncRollbackPhase() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getSyncRollbackPhase() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getTable() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getTagContents(Element, String, String, String) - Static method in class org.jboss.cache.xml.XmlHelper
Returns the contents of a specific node of given element name, provided a certain attribute exists and is set to value.
getTargetFqn() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getTargetFqn() - Method in interface org.jboss.cache.notifications.event.NodeMovedEvent
 
getTargetFqn() - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
getterMethod(Class, Class) - Static method in class org.jboss.cache.util.BeanUtils
Returns a Method object corresponding to a getter that retrieves an instance of componentClass from target.
getterName(Class) - Static method in class org.jboss.cache.util.BeanUtils
Returns a getter for a given class
getTimeout() - Method in class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
getTimeout() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
getTimeSinceReset() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
getTimeSinceReset() - Method in interface org.jboss.cache.interceptors.CacheMgmtInterceptorMBean
Returns seconds since cache statistics reset If statistics haven't been reset, this will be the same as ElapsedTime
getTimeToLiveSeconds() - Method in class org.jboss.cache.eviction.ExpirationConfiguration
 
getTimeToLiveSeconds() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
getTransaction() - Method in class org.jboss.cache.InvocationContext
Retrieves the transaction associated with this invocation
getTransaction() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getTransaction() - Method in interface org.jboss.cache.notifications.event.TransactionalEvent
 
getTransaction() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Get the transaction associated with the calling thread.
getTransaction() - Method in class org.jboss.cache.transaction.TransactionEntry
Returns a local transaction associated with this TransactionEntry
getTransactionManager() - Method in class org.jboss.cache.CacheImpl
Returns the transaction manager in use.
getTransactionManager() - Method in interface org.jboss.cache.CacheSPI
Retrieves a reference to a running TransactionManager, if one is configured.
getTransactionManager() - Method in class org.jboss.cache.config.RuntimeConfig
 
getTransactionManager() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getTransactionManager() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getTransactionManager() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getTransactionManager() - Method in class org.jboss.cache.transaction.BatchModeTransactionManagerLookup
 
getTransactionManager() - Method in class org.jboss.cache.transaction.DummyTransactionManagerLookup
 
getTransactionManager() - Method in class org.jboss.cache.transaction.GenericTransactionManagerLookup
Get the systemwide used TransactionManager
getTransactionManager() - Method in class org.jboss.cache.transaction.JBossStandaloneJTAManagerLookup
 
getTransactionManager() - Method in class org.jboss.cache.transaction.JBossTransactionManagerLookup
 
getTransactionManager() - Method in interface org.jboss.cache.transaction.TransactionManagerLookup
Returns a new TransactionManager.
getTransactionManagerLookupClass() - Method in class org.jboss.cache.config.Configuration
 
getTransactionManagerLookupClass() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getTransactionManagerLookupClass() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getTransactionTable() - Method in class org.jboss.cache.CacheImpl
Returns the transaction table.
getTransactionTable() - Method in interface org.jboss.cache.CacheSPI
Retrieves the current TransactionTable instance associated with the current Cache instance.
getTransactionTable() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getTransactionWorkspace(GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticInterceptor
 
getTransactionWorkspace(GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
getTransactionWorkspace() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Retrieves a TransactionWorkspace instance associated with the current transaction, which the current WorkspaceNode instance lives in.
getTransactionWorkspace() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getTransactionWorkSpace() - Method in class org.jboss.cache.transaction.OptimisticTransactionEntry
 
getType() - Method in class org.jboss.cache.Modification
Returns the type of modification.
getType() - Method in interface org.jboss.cache.notifications.event.Event
 
getType() - Method in class org.jboss.cache.notifications.event.EventImpl
 
getUndoOperations() - Method in class org.jboss.cache.transaction.TransactionEntry
Returns the undo operations in use.
getUniqueId(String) - Static method in class org.jboss.cache.jmx.JmxUtil
 
getUnmarshalledMap() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
getUnversionedMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
Counterpart to MethodDeclarations.getVersionedMethod(int)
getUnversionedMethodId(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
getUpdateNodeSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getUpdateTableSql() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
getUseAsyncPut() - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
getUseInterceptorMbeans() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getUseInterceptorMbeans() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Deprecated. use LegacyConfiguration.getExposeManagementStatistics()
getUseRegionBasedMarshalling() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Deprecated. 
getUseRegionBasedMarshalling() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Gets whether marshalling uses scoped class loaders on a per region basis.
getUseReplQueue() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
getUseReplQueue() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
getUserTransaction() - Static method in class org.jboss.cache.transaction.DummyTransactionManager
 
getUserTransaction() - Method in class org.jboss.cache.transaction.DummyTransactionManagerLookup
 
getUserTransaction() - Method in class org.jboss.cache.transaction.JBossStandaloneJTAManagerLookup
 
getValue() - Method in class org.jboss.cache.Modification
Returns the modification value.
getVersion() - Method in interface org.jboss.cache.Cache
Returns the version of the cache as a string.
getVersion() - Method in class org.jboss.cache.CacheImpl
Returns the CacheImpl implementation version.
getVersion() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
getVersion() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
getVersion() - Method in interface org.jboss.cache.NodeSPI
Returns the data version of this node if versioning is supported.
getVersion() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Retrieves the data version of the in-memory node.
getVersion() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
getVersion() - Method in class org.jboss.cache.UnversionedNode
 
getVersion() - Method in class org.jboss.cache.VersionedNode
Returns the version id of this node.
getVersionedMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
Returns the versioned equivalent of a crud method.
getVersionedMethodId(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
getVersionShort() - Static method in class org.jboss.cache.Version
 
getVersionShort(String) - Static method in class org.jboss.cache.Version
 
getVersionString(short) - Static method in class org.jboss.cache.Version
 
getWakeupIntervalSeconds() - Method in class org.jboss.cache.config.EvictionConfig
 
getWarnNoExpirationKey() - Method in class org.jboss.cache.eviction.ExpirationConfiguration
Returns true if the algorithm should warn if a expiration key is missing for a node.
getWorkspace(GlobalTransaction) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
getWriterOwner() - Method in class org.jboss.cache.lock.IdentityLock
Return the writer lock owner object.
getWriterOwner() - Method in interface org.jboss.cache.lock.NodeLock
Returns the writer lock owner object.
GlobalTransaction - Class in org.jboss.cache.transaction
Uniquely identifies a transaction that spans all nodes in a cluster.
GlobalTransaction() - Constructor for class org.jboss.cache.transaction.GlobalTransaction
empty ctor used by externalization
gravitateData(Fqn, boolean) - Method in class org.jboss.cache.CacheImpl
Used with buddy replication's data gravitation interceptor.
gravitateData(Fqn<?>, boolean) - Method in interface org.jboss.cache.CacheSPI
Used with buddy replication's data gravitation interceptor.
gravitateData(Fqn, boolean) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
GravitateResult - Class in org.jboss.cache.buddyreplication
A class that encapsulates the result of a data gravitation call, a part of the Buddy Replication framwork.
greedyGetFqns(List<Fqn>, NodeSPI<?, ?>, Fqn) - Method in class org.jboss.cache.interceptors.OptimisticInterceptor
Adds the Fqn of the node as well as all children and childrens children to the list.

H

handle(Message) - Method in class org.jboss.cache.marshall.InactiveRegionAwareRpcDispatcher
Message contains MethodCall.
handleAddChildMethod(InvocationContext, GlobalTransaction, Fqn, Object, Node, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleAddChildMethod(InvocationContext, GlobalTransaction, Fqn, Object, Node, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleAddChildMethod(InvocationContext, GlobalTransaction, Fqn, Object, Node, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._addChild(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, Object, org.jboss.cache.Node, boolean)
handleAddChildMethod(InvocationContext, GlobalTransaction, Fqn, Object, Node, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleAddChildMethod(InvocationContext, GlobalTransaction, Fqn, Object, Node, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleAssignToBuddyGroup(BuddyGroup, Map<Fqn, byte[]>) - Method in class org.jboss.cache.buddyreplication.BuddyManager
Called by CacheImpl.
handleBlockChannelMethod(InvocationContext) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._block()
handleBlockChannelMethod(InvocationContext) - Method in class org.jboss.cache.interceptors.NotificationInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl.commit(org.jboss.cache.transaction.GlobalTransaction)
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.NotificationInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticLockingInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticValidatorInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleCommitMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleDataGravitationCleanupMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleDataGravitationCleanupMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles RemoteCacheInvocationDelegate.dataGravitationCleanup(org.jboss.cache.Fqn, org.jboss.cache.Fqn)
handleDataGravitationCleanupMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleDataGravitationCleanupMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleEvictMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handleEvictMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleEvictMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles evict()
handleEvictMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PassivationInterceptor
Notifies the cache instance listeners that the evicted node is about to be passivated and stores the evicted node and its attributes back to the store using the CacheLoader.
handleEvictMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleEvictMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleEvictVersionedNodeMethod(InvocationContext, Fqn, DataVersion) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handleEvictVersionedNodeMethod(InvocationContext, Fqn, DataVersion) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleEvictVersionedNodeMethod(InvocationContext, Fqn, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._evict(org.jboss.cache.Fqn, org.jboss.cache.optimistic.DataVersion)
handleEvictVersionedNodeMethod(InvocationContext, Fqn, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleExistsMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleExistsMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl.exists(String)
handleExistsMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleGetChildrenNamesMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleGetChildrenNamesMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleGetChildrenNamesMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleGetChildrenNamesMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._getChildrenNames(org.jboss.cache.Fqn)
handleGetChildrenNamesMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleGetChildrenNamesMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleGetDataMapMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleGetDataMapMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleGetDataMapMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleGetDataMapMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._getData(org.jboss.cache.Fqn)
handleGetDataMapMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleGetKeysMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleGetKeysMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleGetKeysMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleGetKeysMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles Cache.getKeys(Fqn)
handleGetKeysMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleGetKeysMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._get(org.jboss.cache.Fqn, Object, boolean)
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleGetKeyValueMethod(InvocationContext, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._get(org.jboss.cache.Fqn)
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleGetNodeMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleLockMethod(InvocationContext, Fqn, NodeLock.LockType, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._lock(org.jboss.cache.Fqn, org.jboss.cache.lock.NodeLock.LockType, boolean)
handleLockMethod(InvocationContext, Fqn, NodeLock.LockType, boolean) - Method in class org.jboss.cache.interceptors.OptimisticLockingInterceptor
 
handleLockMethod(InvocationContext, Fqn, NodeLock.LockType, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleLockMethod(InvocationContext, Fqn, NodeLock.LockType, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._move(org.jboss.cache.Fqn, org.jboss.cache.Fqn)
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleMoveMethod(InvocationContext, Fqn, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl.optimisticPrepare(org.jboss.cache.transaction.GlobalTransaction, java.util.List, java.util.Map, org.jgroups.Address, boolean)
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.OptimisticLockingInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.OptimisticValidatorInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleOptimisticPrepareMethod(InvocationContext, GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePoolNameBroadcast(Address, String) - Method in class org.jboss.cache.buddyreplication.BuddyManager
Called by CacheImpl.
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl.prepare(org.jboss.cache.transaction.GlobalTransaction, java.util.List, org.jgroups.Address, boolean)
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePrepareMethod(InvocationContext, GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePrintMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handlePrintMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handlePrintMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._print(org.jboss.cache.Fqn)
handlePrintMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handlePrintMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._put(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, java.util.Map, boolean, boolean)
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutDataEraseMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutDataEraseVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePutDataEraseVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._put(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, java.util.Map, boolean, boolean, org.jboss.cache.optimistic.DataVersion)
handlePutDataEraseVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutDataEraseVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutDataEraseVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._put(org.jboss.cache.transaction.GlobalTransaction, String, java.util.Map, boolean)
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutDataMethod(InvocationContext, GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, Boolean, DataVersion) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePutDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, Boolean, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._put(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, java.util.Map, boolean, org.jboss.cache.optimistic.DataVersion)
handlePutDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, Boolean, DataVersion) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, Boolean, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Map, Boolean, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._putForExternalRead(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, Object, Object)
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutForExternalReadMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutForExternalReadVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._putForExternalRead(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, Object, Object, org.jboss.cache.optimistic.DataVersion)
handlePutForExternalReadVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, DataVersion) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutForExternalReadVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, DataVersion) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
handlePutForExternalReadVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutForExternalReadVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._put(org.jboss.cache.transaction.GlobalTransaction, String, Object, Object, boolean)
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutKeyValueMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handlePutKeyValueVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handlePutKeyValueVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._put(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, Object, Object, boolean, org.jboss.cache.optimistic.DataVersion)
handlePutKeyValueVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
handlePutKeyValueVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handlePutKeyValueVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleReleaseAllLocksMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleReleaseAllLocksMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleReleaseAllLocksMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._releaseAllLocks(org.jboss.cache.Fqn)
handleReleaseAllLocksMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleReleaseAllLocksMethod(InvocationContext, Fqn) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._removeData(org.jboss.cache.transaction.GlobalTransaction, Fqn, boolean)
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRemoveDataMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRemoveDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRemoveDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._removeData(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, boolean, org.jboss.cache.optimistic.DataVersion)
handleRemoveDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRemoveDataVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRemovedAttributes(XmlConfigurationParser.ParsedAttributes) - Method in class org.jboss.cache.factories.XmlConfigurationParser
Check for and remove any attributes that were supported in the 1.x releases and no longer are.
handleRemoveFromBuddyGroup(String) - Method in class org.jboss.cache.buddyreplication.BuddyManager
Called by CacheImpl.
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._remove(org.jboss.cache.transaction.GlobalTransaction, String, Object, boolean)
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRemoveKeyMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRemoveKeyVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRemoveKeyVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._remove(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, Object, boolean, org.jboss.cache.optimistic.DataVersion)
handleRemoveKeyVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRemoveKeyVersionedMethod(InvocationContext, GlobalTransaction, Fqn, Object, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
remove() methods need to be applied to the CacheLoader before passing up the call: a listener might access an element just removed, causing the CacheLoader to *load* the element before *removing* it.
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.EvictionInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._remove(org.jboss.cache.transaction.GlobalTransaction, String, boolean)
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRemoveNodeMethod(InvocationContext, GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRemoveNodeVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRemoveNodeVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._remove(org.jboss.cache.transaction.GlobalTransaction, org.jboss.cache.Fqn, boolean, org.jboss.cache.optimistic.DataVersion)
handleRemoveNodeVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRemoveNodeVersionedMethod(InvocationContext, GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl.rollback(org.jboss.cache.transaction.GlobalTransaction)
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.NotificationInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticLockingInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.OptimisticValidatorInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
handleRollbackMethod(InvocationContext, GlobalTransaction) - Method in class org.jboss.cache.interceptors.TxInterceptor
 
handleUnblockChannelMethod(InvocationContext) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Handles CacheImpl._unblock()
handleUnblockChannelMethod(InvocationContext) - Method in class org.jboss.cache.interceptors.NotificationInterceptor
 
handleViewChange(ViewChangedEvent) - Method in class org.jboss.cache.buddyreplication.BuddyManager.ViewChangeListener
 
hasChild(Fqn) - Method in class org.jboss.cache.CacheImpl
Returns true if the FQN exists and the node has children.
hasChild(Fqn<?>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
hasChild(Object) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
hasChild(Fqn<?>) - Method in interface org.jboss.cache.Node
Returns true if the child node denoted by the relative Fqn passed in exists.
hasChild(Object) - Method in interface org.jboss.cache.Node
Returns true if the child node denoted by the Object name passed in exists.
hasChild(Object) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
hasChild(Fqn) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
hasChildrenDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
hasChildrenDirect() - Method in interface org.jboss.cache.NodeSPI
 
hasChildrenDirect() - Method in class org.jboss.cache.UnversionedNode
 
hasElement(E) - Method in class org.jboss.cache.Fqn
 
hashCode() - Method in class org.jboss.cache.AbstractNode
 
hashCode() - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
hashCode() - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
hashCode() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
hashCode() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
hashCode() - Method in class org.jboss.cache.config.Configuration
 
hashCode() - Method in class org.jboss.cache.config.EvictionConfig
 
hashCode() - Method in class org.jboss.cache.config.EvictionRegionConfig
 
hashCode() - Method in class org.jboss.cache.config.Option
 
hashCode() - Method in class org.jboss.cache.config.RuntimeConfig
 
hashCode() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
hashCode() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
hashCode() - Method in class org.jboss.cache.eviction.LFUConfiguration
 
hashCode() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
hashCode() - Method in class org.jboss.cache.eviction.NodeEntry
 
hashCode() - Method in class org.jboss.cache.Fqn
Returns a hash code with Fqn elements.
hashCode() - Method in class org.jboss.cache.InvocationContext
 
hashCode() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
hashCode() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
hashCode() - Method in class org.jboss.cache.marshall.MarshalledValue
 
hashCode() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
hashCode() - Method in class org.jboss.cache.marshall.NodeData
 
hashCode() - Method in class org.jboss.cache.notifications.event.EventImpl
 
hashCode() - Method in class org.jboss.cache.optimistic.DefaultDataVersion
 
hashCode() - Method in class org.jboss.cache.transaction.GlobalTransaction
 
hashCode() - Method in class org.jboss.cache.util.BitEncodedIntegerSet
 
hashCode() - Method in class org.jboss.cache.util.Util.MapModifications
 
hashCodeExcludingProperties() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
hasNode(Fqn) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
returns true if the workspace contains a node with specified Fqn
hasNode(Fqn) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
hasRegion(Fqn, Region.Type) - Method in class org.jboss.cache.RegionManager
Returns true if the region exists

I

IdentityLock - Class in org.jboss.cache.lock
Lock object which grants and releases locks, and associates locks with owners.
IdentityLock(NodeSPI) - Constructor for class org.jboss.cache.lock.IdentityLock
Creates a new Identity lock based on the lock level set in the LockStrategyFactory
IdentityLock(IsolationLevel, NodeSPI) - Constructor for class org.jboss.cache.lock.IdentityLock
Creates a new IdentityLock based on the lock level in force.
InactiveRegionAwareRpcDispatcher - Class in org.jboss.cache.marshall
Extends RpcDispatcher and adds the possibility that the marshaller may throw InactiveRegionExceptions.
InactiveRegionAwareRpcDispatcher(Channel, MessageListener, MembershipListener, Object) - Constructor for class org.jboss.cache.marshall.InactiveRegionAwareRpcDispatcher
Only provide the flavour of the RpcDispatcher constructor that we care about.
InactiveRegionException - Exception in org.jboss.cache.marshall
Thrown by a AbstractMarshaller instance when attempting to perform an operation on an inactive region.
InactiveRegionException() - Constructor for exception org.jboss.cache.marshall.InactiveRegionException
 
InactiveRegionException(String) - Constructor for exception org.jboss.cache.marshall.InactiveRegionException
 
InactiveRegionException(String, Throwable) - Constructor for exception org.jboss.cache.marshall.InactiveRegionException
 
IncorrectCacheListenerException - Exception in org.jboss.cache.notifications
Thrown when an incorrectly annotated class is added as a cache listener using the Cache.addCacheListener(Object) API.
IncorrectCacheListenerException(String) - Constructor for exception org.jboss.cache.notifications.IncorrectCacheListenerException
 
increment() - Method in class org.jboss.cache.optimistic.DefaultDataVersion
Returns a new DataVersion with a newer version number.
init(BuddyReplicationConfig.BuddyLocatorConfig) - Method in interface org.jboss.cache.buddyreplication.BuddyLocator
Initialize this BuddyLocator.
init() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
init(BuddyReplicationConfig.BuddyLocatorConfig) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocator
 
init(int) - Method in class org.jboss.cache.eviction.EvictionTimerTask
 
init() - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
init(byte[]) - Method in class org.jboss.cache.marshall.io.ReusableObjectInputStream
Initialises the stream to read from the byte buffer passed in
init() - Method in class org.jboss.cache.marshall.io.ReusableObjectOutputStream
Initialises a pooled stream for use.
init() - Method in class org.jboss.cache.NodeFactory
Initialises the node factory with the configuration from the cache.
INIT_BYTES - Static variable in class org.jboss.cache.marshall.io.ReusableObjectInputStream
 
initialize(Region) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
initialValue() - Method in class org.jboss.cache.invocation.InvocationContextContainer
 
initLogger() - Method in class org.jboss.cache.interceptors.Interceptor
 
initLogger() - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
initReplicationVersions() - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
Inject - Annotation Type in org.jboss.cache.factories.annotations
Used to annotate a method as one that is used to inject a registered component into another component.
injectDependencies(TransactionTable, CacheLoaderManager, Configuration) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
injectDependencies(Notifier, NodeFactory) - Method in class org.jboss.cache.interceptors.OptimisticNodeInterceptor
 
injectDependencies(Configuration, CacheImpl, TransactionTable) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
insertNode(Fqn, Map) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Inserts a node into the database
INSTANCE - Static variable in class org.jboss.cache.eviction.NullEvictionAlgorithm
Singleton instance of this class.
INSTANCE - Static variable in class org.jboss.cache.eviction.NullEvictionQueue
Singleton instance of this class.
INSTANCE - Static variable in class org.jboss.cache.FqnComparator
 
instance - Variable in class org.jboss.cache.marshall.MarshalledValue
 
integrateAssociatedState(ObjectInputStream) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
Provided for subclasses that deal with associated state.
integratePersistentState(ObjectInputStream) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
integrateState(ObjectInputStream, Node) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
integrateState(ObjectInputStream, Node) - Method in interface org.jboss.cache.statetransfer.StateTransferIntegrator
 
integrateTransientState(ObjectInputStream, NodeSPI) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
Interceptor - Class in org.jboss.cache.interceptors
Class representing an interceptor.
Interceptor() - Constructor for class org.jboss.cache.interceptors.Interceptor
 
INTERCEPTOR_KEY - Static variable in class org.jboss.cache.jmx.JmxUtil
 
interceptorChain - Variable in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
InterceptorChainFactory - Class in org.jboss.cache.factories
Factory class that builds an interceptor chain based on cache configuration.
InterceptorChainFactory() - Constructor for class org.jboss.cache.factories.InterceptorChainFactory
 
InterceptorMBean - Interface in org.jboss.cache.interceptors
Interface containing common cache management operations
invalidate(Fqn, DataVersion) - Method in class org.jboss.cache.CacheImpl
Very much like an evict(), except that regardless of whether there is a child present, this call will never remove the node from memory - just remove its contents.
invalidateAcrossCluster(Fqn, TransactionWorkspace, InvocationContext) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
Deprecated. use {@link #invalidateAcrossCluster(Fqn,TransactionWorkspace,boolean,InvocationContext)
invalidateAcrossCluster(Fqn, TransactionWorkspace, boolean, InvocationContext) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
invalidateMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
invalidateMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
invalidateModifications(List<MethodCall>, TransactionWorkspace, InvocationContext) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
Deprecated. use InvalidationInterceptor.invalidateAcrossCluster(org.jboss.cache.Fqn,org.jboss.cache.optimistic.TransactionWorkspace,boolean,InvocationContext)
invalidateModifications(List<MethodCall>, TransactionWorkspace, boolean, InvocationContext) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
InvalidationInterceptor - Class in org.jboss.cache.interceptors
This interceptor acts as a replacement to the replication interceptor when the CacheImpl is configured with ClusteredSyncMode as INVALIDATE.
InvalidationInterceptor() - Constructor for class org.jboss.cache.interceptors.InvalidationInterceptor
 
InvalidationInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing invalidation statistics
InvocationContext - Class in org.jboss.cache
This context holds information specific to a method invocation.
InvocationContext() - Constructor for class org.jboss.cache.InvocationContext
 
invocationContextContainer - Variable in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
InvocationContextContainer - Class in org.jboss.cache.invocation
Container and factory for thread locals
InvocationContextContainer() - Constructor for class org.jboss.cache.invocation.InvocationContextContainer
 
InvocationContextInterceptor - Class in org.jboss.cache.interceptors
Always place this interceptor at the start of the interceptor chain to ensure invocation contexts and set up and cleaned up correctly.
InvocationContextInterceptor() - Constructor for class org.jboss.cache.interceptors.InvocationContextInterceptor
 
InvocationContextInterceptorMBean - Interface in org.jboss.cache.interceptors
MBean to the InvocationContextInterceptor
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.CallInterceptor
 
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.Interceptor
Using this method call for forwarding a call in the chain is not redable and error prone in the case of interceptors extending other interceptors.
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.InvocationContextInterceptor
 
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.MarshalledValueInterceptor
 
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Acts like a 'switch case' that delegates the call to the appropriate method.
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.OptimisticNodeInterceptor
 
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
invoke(InvocationContext) - Method in class org.jboss.cache.interceptors.UnlockInterceptor
Deprecated.  
invoke(MethodCall) - Method in class org.jboss.cache.invocation.AbstractInvocationDelegate
Passes a method call up the interceptor chain.
invoke(MethodCall, boolean) - Method in class org.jboss.cache.invocation.AbstractInvocationDelegate
Passes a method call up the interceptor chain, optionally allowing you to skip cache status checks.
invokeWithRetries(Method, Object...) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
Invokes the specified Method with the specified parameters, catching SocketExceptions and attempting to reconnect to the TcpCacheServer if necessary.
IRE - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
isAcceptable(Object, Address) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor.ResponseValidityFilter
 
isAcceptable(Object, Address) - Method in class org.jboss.cache.loader.ClusteredCacheLoader.ResponseValidityFilter
 
isActivation - Variable in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
isActive(Transaction) - Method in class org.jboss.cache.interceptors.Interceptor
Returns true if transaction is ACTIVE, false otherwise
isActive() - Method in interface org.jboss.cache.Region
Returns true if this region has been activated.
isActive() - Method in class org.jboss.cache.RegionImpl
 
isAPIMethodCall(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
Returns true if the method call is declared in the public Cache API.
isAsync() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
isAutoDataGravitation() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
isAutoDataGravitation() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
isBackupFqn(Fqn) - Static method in class org.jboss.cache.buddyreplication.BuddyManager
 
isBefore124(short) - Static method in class org.jboss.cache.Version
 
isBlockUnblockMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
isBuddyGroupOrganisationMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
isCacheLoaderHasMods() - Method in class org.jboss.cache.InvocationContext
Cache loader might have mods which are different from TX's mods; e.g. when cache is local and passivation is on.
isCacheModeLocal() - Method in class org.jboss.cache.config.Option
only applies to put() and remove() methods on the cache.
isCacheReady() - Method in class org.jboss.cache.loader.ClusteredCacheLoader
A test to check whether the cache is in it's started state.
isCharacterPortableLocation(String) - Method in class org.jboss.cache.loader.FileCacheLoader
 
isCharacterPortableTree(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
isCheckCharacterPortability() - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
isChildOf(Fqn<E>) - Method in class org.jboss.cache.Fqn
Returns true if this Fqn is child of parentFqn.
isChildOrEquals(Fqn<E>) - Method in class org.jboss.cache.Fqn
Returns true if this Fqn is equals or the child of parentFqn.
isChildrenLoaded() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
isChildrenLoaded() - Method in interface org.jboss.cache.NodeSPI
Returns true if the children of this node were loaded from a cache loader.
isChildrenLoaded() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
 
isChildrenLoaded() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isChildrenLoaded() - Method in class org.jboss.cache.UnversionedNode
 
isChildrenModified() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
 
isChildrenModified() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isCoordinator() - Method in interface org.jboss.cache.RPCManager
 
isCoordinator() - Method in class org.jboss.cache.RPCManagerImpl
 
isCreated() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
 
isCreated() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isCrudMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
Returns true if the method is a CRUD method.
isCurrentlyInUse() - Method in class org.jboss.cache.eviction.NodeEntry
Is the node currently in use.
isDataFound() - Method in class org.jboss.cache.buddyreplication.GravitateResult
 
isDataGravitationMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
isDataGravitationRemoveOnFind() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
isDataGravitationRemoveOnFind() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
isDataGravitationSearchBackupTrees() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
isDataGravitationSearchBackupTrees() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
isDataLoaded() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
isDataLoaded() - Method in interface org.jboss.cache.NodeSPI
Returns true if the data was loaded from the cache loader.
isDataLoaded() - Method in class org.jboss.cache.UnversionedNode
Returns true if the data was loaded from the cache loader.
isDefaultInactive() - Method in class org.jboss.cache.RegionManager
 
isDeleted() - Method in class org.jboss.cache.AbstractNode
 
isDeleted() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
isDeleted() - Method in interface org.jboss.cache.NodeSPI
Returns true if the instance has been deleted in the current transaction.
isDeleted() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
 
isDirty() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
A convenience method that returns whether a node is dirty, i.e., it has been created, deleted or modified.
isDirty() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
A convenience method that returns whether a node is dirty, i.e., it has been created, deleted or modified.
isDisableStateChangeNotifications() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Gets whether sending of JMX notifications for this mbean's start/stop lifecycle changes is disabled.
isEmpty() - Method in class org.jboss.cache.lock.ThreadLocalMap
 
isEmpty() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
isEmpty() - Method in class org.jboss.cache.util.BitEncodedIntegerSet
Tests if the set is empty
isEmpty() - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
isEnabled() - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
isEnabled() - Method in class org.jboss.cache.cluster.ReplicationQueue
 
isEnabled() - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
isExceptionMarker() - Method in class org.jboss.cache.marshall.NodeData
 
isExceptionMarker() - Method in class org.jboss.cache.marshall.NodeDataExceptionMarker
 
isFailSilently() - Method in class org.jboss.cache.config.Option
 
isFetchInMemoryState() - Method in class org.jboss.cache.config.Configuration
 
isFetchPersistentState() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
isFetchPersistentState() - Method in class org.jboss.cache.config.CacheLoaderConfig
Loops through all individual cache loader configs and checks if fetchPersistentState is set on any of them
isFetchPersistentState() - Method in class org.jboss.cache.loader.CacheLoaderManager
Returns true if at least one of the configured cache loaders has set fetchPersistentState to true.
isForceAsynchronous() - Method in class org.jboss.cache.config.Option
Gets whether replication or invalidation should be done asynchronously, even if the cache is configured in a synchronous mode.
isForceAsyncReplication() - Method in class org.jboss.cache.transaction.TransactionEntry
Gets the value of the forceAsyncReplication flag.
isForceSynchronous() - Method in class org.jboss.cache.config.Option
Gets whether replication or invalidation should be done synchronously, even if the cache is configured in an asynchronous mode.
isForceSyncReplication() - Method in class org.jboss.cache.transaction.TransactionEntry
Gets the value of the forceSyncReplication flag.
isForceWriteLock() - Method in class org.jboss.cache.config.Option
Tests whether a write lock has been forced on the call, regardless of whether it is a read or write.
isGetMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
isIgnoreColocatedBuddies() - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
isIgnoreModifications() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
isInactive(Fqn) - Method in class org.jboss.cache.RegionManager
Convenienve method.
isInactiveOnStartup() - Method in class org.jboss.cache.config.Configuration
 
isInactiveOnStartup() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
isInactiveOnStartup() - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Gets whether the entire tree is inactive upon startup, only responding to replication messages after activateRegion is called to activate one or more parts of the tree.
isInternalCollection(int, int) - Method in class org.jboss.cache.interceptors.MarshalledValueInterceptor
prepare methods include Maps and Lists in args.
isInvalidation() - Method in enum org.jboss.cache.config.Configuration.CacheMode
Returns true if the mode is invalidation, either sync or async.
isLengthPortablePath(String) - Method in class org.jboss.cache.loader.FileCacheLoader
 
isLocalRollbackOnly() - Method in class org.jboss.cache.InvocationContext
 
isLocked() - Method in class org.jboss.cache.lock.IdentityLock
Check if there is a read or write lock
isLocked() - Method in interface org.jboss.cache.lock.NodeLock
Check if there is a read or write lock
isLockForChildInsertRemove() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
isLockForChildInsertRemove() - Method in interface org.jboss.cache.Node
Tests whether this node is configured to be exclusively locked when inserting or removing children.
isLockForChildInsertRemove() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isLockForChildInsertRemove() - Method in class org.jboss.cache.UnversionedNode
 
isLockParentForChildInsertRemove() - Method in class org.jboss.cache.config.Configuration
Gets whether inserting or removing a node requires a write lock on the node's parent (when pessimistic locking is used.)
isMarker() - Method in class org.jboss.cache.marshall.NodeData
 
isMarker() - Method in class org.jboss.cache.marshall.NodeDataMarker
 
isModified() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
A node is considered modified if it's data map has changed.
isModified() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
Returns true if this node is modified.
isModified() - Method in class org.jboss.cache.util.DeltaMap
Returns true if the internal map was modified.
isNodeInUseAndNotTimedOut(NodeEntry) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
isNodeLockingOptimistic() - Method in class org.jboss.cache.config.Configuration
 
isNodeRemovedInTx(GlobalTransaction, Fqn) - Method in class org.jboss.cache.transaction.TransactionTable
 
IsolationLevel - Enum in org.jboss.cache.lock
Various transaction isolation levels as an enumerated class.
isOnePhaseCommitPrepareMehod() - Method in class org.jboss.cache.marshall.MethodCall
This only works for prepare() and optimisticPrepare() method calls.
isOptionsUninitialised() - Method in class org.jboss.cache.InvocationContext
 
isOriginLocal() - Method in class org.jboss.cache.InvocationContext
Tests if this invocation originated locally or from a remote cache.
isOriginLocal() - Method in class org.jboss.cache.notifications.event.EventImpl
 
isOriginLocal() - Method in interface org.jboss.cache.notifications.event.TransactionalEvent
 
isOwner(Object) - Method in class org.jboss.cache.lock.IdentityLock
Am I a lock owner?
isOwner(Object, int) - Method in class org.jboss.cache.lock.LockMap
Check whether this owner has reader or writer ownership.
isOwner(Object) - Method in interface org.jboss.cache.lock.NodeLock
Returns true if the object is the lock owner.
isPassivation() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
isPassivation() - Method in class org.jboss.cache.loader.CacheLoaderManager
Tests if we're using passivation
isPre() - Method in interface org.jboss.cache.notifications.event.Event
 
isPre() - Method in class org.jboss.cache.notifications.event.EventImpl
 
isPreparing(Transaction) - Method in class org.jboss.cache.interceptors.Interceptor
Returns true if transaction is PREPARING, false otherwise
isPurgeOnStartup() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
isPushStateWhenCoordinator() - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
isPutMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
isReadLocked() - Method in class org.jboss.cache.lock.IdentityLock
Check if there is a read lock.
isReadLocked() - Method in class org.jboss.cache.lock.LockMap
 
isReadLocked() - Method in interface org.jboss.cache.lock.NodeLock
Check if there is a read lock.
isRegionRegisteredForProcessing(Region) - Method in class org.jboss.cache.eviction.EvictionTimerTask
 
isRemote() - Method in class org.jboss.cache.transaction.GlobalTransaction
 
isReplicateAllMethod(MethodCall) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
isReplicateMethod(MethodCall) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
isResetElementCount() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
isResident() - Method in class org.jboss.cache.AbstractNode
 
isResident() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
isResident() - Method in interface org.jboss.cache.Node
Nodes marked resident would be ignored by the eviction algorithms.
isResurrected() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
 
isResurrected() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isRollingBack(Transaction) - Method in class org.jboss.cache.interceptors.BaseTransactionalContextInterceptor
Returns true if transaction is rolling back, false otherwise
isRoot() - Method in class org.jboss.cache.Fqn
Returns true if this is a root Fqn.
isShared() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
isSingletonStoreEnabled() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
isSingletonStoreEnabled() - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
isSkipCacheStatusCheck() - Method in class org.jboss.cache.config.Option
 
isSkipDataGravitation() - Method in class org.jboss.cache.config.Option
 
isStateSet() - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
isSuccessful() - Method in class org.jboss.cache.notifications.event.EventImpl
 
isSuccessful() - Method in interface org.jboss.cache.notifications.event.TransactionCompletedEvent
 
isSuppressLocking() - Method in class org.jboss.cache.config.Option
 
isSyncCommitPhase() - Method in class org.jboss.cache.config.Configuration
 
isSynchronous(Option) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
isSyncRollbackPhase() - Method in class org.jboss.cache.config.Configuration
 
isTransactionalAndLocal(InvocationContext) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
The call runs in a transaction and it was initiated on this node of the cluster.
isTransactionLifecycleMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
isTxHasMods() - Method in class org.jboss.cache.InvocationContext
 
isTypeExcluded(Class) - Static method in class org.jboss.cache.marshall.MarshalledValueHelper
Tests whether the type should be excluded from MarshalledValue wrapping.
isUseLazyDeserialization() - Method in class org.jboss.cache.config.Configuration
 
isUseLazyDeserialization() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
isUseRegionBasedMarshalling() - Method in class org.jboss.cache.config.Configuration
Deprecated. 
isUseReplQueue() - Method in class org.jboss.cache.config.Configuration
 
isUsingEvictions() - Method in class org.jboss.cache.RegionManager
 
isUsingMultiplexer() - Method in class org.jboss.cache.config.Configuration
 
isValid(Transaction) - Method in class org.jboss.cache.interceptors.Interceptor
Return s true of tx's status is ACTIVE or PREPARING
isValid() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
isValid() - Method in interface org.jboss.cache.Node
Tests if a node reference is still valid.
isValid() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isValid() - Method in class org.jboss.cache.UnversionedNode
 
isValidConfig() - Method in class org.jboss.cache.config.EvictionConfig
 
isVersioningImplicit() - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
Tests if versioning is implicit for a given tx.
isVersioningImplicit() - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
isVersioningImplicit() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Tests whether versioning for the WorkspaceNode instance in the current transaction is implicit (i.e., using DefaultDataVersion rather than a custom DataVersion passed in using Option.setDataVersion(DataVersion))
isVersioningImplicit() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
isWriteLocked() - Method in class org.jboss.cache.lock.IdentityLock
Check if there is a write lock.
isWriteLocked() - Method in interface org.jboss.cache.lock.NodeLock
Check if there is a write lock.
isYoungerThanMinimumTimeToLive(NodeEntry) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Tests whether a node entry is younger than the minimum time to live - if one is configured.
iterate() - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
iterate() - Method in interface org.jboss.cache.eviction.EvictionQueue
 
iterate() - Method in class org.jboss.cache.eviction.FIFOQueue
 
iterate() - Method in class org.jboss.cache.eviction.LFUQueue
 
iterate() - Method in class org.jboss.cache.eviction.LRUQueue
 
iterate() - Method in class org.jboss.cache.eviction.MRUQueue
 
iterate() - Method in class org.jboss.cache.eviction.NullEvictionQueue
Returns an Iterator whose hasNext() returns false.
iterator() - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 

J

JBOSS_CACHE_DOMAIN - Static variable in class org.jboss.cache.jmx.JmxUtil
 
JBOSS_SERVER_DOMAIN - Static variable in class org.jboss.cache.jmx.JmxUtil
 
JBossStandaloneJTAManagerLookup - Class in org.jboss.cache.transaction
JTA standalone TM lookup.
JBossStandaloneJTAManagerLookup() - Constructor for class org.jboss.cache.transaction.JBossStandaloneJTAManagerLookup
 
JBossTransactionManagerLookup - Class in org.jboss.cache.transaction
Uses JNDI to look-up the TransactionManager instance from "java:/TransactionManager".
JBossTransactionManagerLookup() - Constructor for class org.jboss.cache.transaction.JBossTransactionManagerLookup
 
JDBCCacheLoader - Class in org.jboss.cache.loader
JDBC implementation of AdjListJDBCCacheLoader.
JDBCCacheLoader() - Constructor for class org.jboss.cache.loader.JDBCCacheLoader
 
JDBCCacheLoaderConfig - Class in org.jboss.cache.loader
Builds the different SQLs needed by JDBCCacheLoader.
JDBCCacheLoaderConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Constructor for class org.jboss.cache.loader.JDBCCacheLoaderConfig
 
JDBCCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.JDBCCacheLoaderConfig
 
JDBCCacheLoaderOld - Class in org.jboss.cache.loader
Deprecated. please use the JDBCCacheLoader.
JDBCCacheLoaderOld() - Constructor for class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated.  
JDBCCacheLoaderOldConfig - Class in org.jboss.cache.loader
Deprecated. please use JDBCCacheLoaderConfig
JDBCCacheLoaderOldConfig() - Constructor for class org.jboss.cache.loader.JDBCCacheLoaderOldConfig
Deprecated.  
JdbmCacheLoader - Class in org.jboss.cache.loader.jdbm
A persistent CacheLoader based on the JDBM project.
JdbmCacheLoader() - Constructor for class org.jboss.cache.loader.jdbm.JdbmCacheLoader
 
JdbmCacheLoaderConfig - Class in org.jboss.cache.loader.jdbm
 
JdbmCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
JmxUtil - Class in org.jboss.cache.jmx
Various JMX related utilities
JmxUtil() - Constructor for class org.jboss.cache.jmx.JmxUtil
 

K

keySet() - Method in class org.jboss.cache.lock.ThreadLocalMap
 
keySet() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 

L

last - Variable in class org.jboss.cache.interceptors.Interceptor
 
LegacyConfiguration - Interface in org.jboss.cache.jmx
Legacy configuration attributes from JBC 1.x.
legacyModeToCacheMode(int) - Static method in class org.jboss.cache.config.Configuration
 
LFUAlgorithm - Class in org.jboss.cache.eviction
Least Frequently Used algorithm for cache eviction.
LFUAlgorithm() - Constructor for class org.jboss.cache.eviction.LFUAlgorithm
 
LFUConfiguration - Class in org.jboss.cache.eviction
Configuration implementation for LFUPolicy.
LFUConfiguration() - Constructor for class org.jboss.cache.eviction.LFUConfiguration
 
LFUPolicy - Class in org.jboss.cache.eviction
Least Frequently Used Eviction Policy.
LFUPolicy() - Constructor for class org.jboss.cache.eviction.LFUPolicy
 
LFUQueue - Class in org.jboss.cache.eviction
LFUQueue EvictionQueue implementation for LFU Policy.
list(Name) - Method in class org.jboss.cache.transaction.DummyContext
Enumerates the names bound in the named context, along with the class names of objects bound to them.
list(String) - Method in class org.jboss.cache.transaction.DummyContext
Enumerates the names bound in the named context, along with the class names of objects bound to them.
listBindings(Name) - Method in class org.jboss.cache.transaction.DummyContext
Enumerates the names bound in the named context, along with the objects bound to them.
listBindings(String) - Method in class org.jboss.cache.transaction.DummyContext
Enumerates the names bound in the named context, along with the objects bound to them.
listen() - Method in class org.jboss.cache.ConsoleListener
Instructs this class to listen for cache replication events.
listen(boolean) - Method in class org.jboss.cache.ConsoleListener
Instructs this class to listen for cache replication events.
LOAD_ENTIRE_STATE - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
loadAttributes(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
loadClass(String) - Static method in class org.jboss.cache.util.Util
Loads the specified class using this class's classloader, or, if it is null (i.e. this class was loaded by the bootstrap classloader), the system classloader.
loadEntireState(ObjectOutputStream) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
loadEntireState(ObjectOutputStream) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
loadEntireState(ObjectOutputStream) - Method in interface org.jboss.cache.loader.CacheLoader
Fetches the entire state for this cache from secondary storage (disk, database) and writes it to a provided ObjectOutputStream.
loadEntireState(ObjectOutputStream) - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
loadEntireState(ObjectOutputStream) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
loadEntireState(ObjectOutputStream) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
loadEntireState(ObjectOutputStream) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
loader - Variable in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
loader - Variable in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
loader - Variable in class org.jboss.cache.interceptors.PassivationInterceptor
 
loaderConfig - Variable in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
loadNode(Fqn) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Loads a node from the database.
loadObject(Fqn) - Method in interface org.jboss.cache.loader.CacheLoaderAop
Loads an object from a persistent store.
loadState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
loadState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
loadState(Fqn, ObjectOutputStream) - Method in interface org.jboss.cache.loader.CacheLoader
Fetches a portion of the state for this cache from secondary storage (disk, database) and writes it to a provided ObjectOutputStream.
loadState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
loadState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
loadState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
loadState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
loadStateHelper(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.loader.AbstractCacheLoader
Do a preorder traversal: visit the node first, then the node's children
loadUninitialisedNode(Fqn) - Method in class org.jboss.cache.transaction.TransactionEntry
 
LocalDelegatingCacheLoader - Class in org.jboss.cache.loader
DelegatingCacheLoader implementation which delegates to a local (in the same VM) CacheImpl.
LocalDelegatingCacheLoader() - Constructor for class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
LocalDelegatingCacheLoaderConfig - Class in org.jboss.cache.loader
 
LocalDelegatingCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
locateBuddies(Map<Address, String>, List<Address>, Address) - Method in interface org.jboss.cache.buddyreplication.BuddyLocator
Choose a set of buddies for the given node.
locateBuddies(Map<Address, String>, List<Address>, Address) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocator
 
lock(Fqn, NodeLock.LockType, boolean) - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
lock - Variable in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
lock - Variable in class org.jboss.cache.loader.FileCacheLoader
 
lock() - Method in class org.jboss.cache.lock.SemaphoreLock
 
lockAndCreateWorkspaceNode(NodeFactory, NodeSPI, TransactionWorkspace, GlobalTransaction, long) - Method in class org.jboss.cache.interceptors.OptimisticInterceptor
 
LockingException - Exception in org.jboss.cache.lock
Used for all locking-related exceptions, e.g. when a lock could not be acquired within the timeout, or when a deadlock was detected or an upgrade failed.
LockingException() - Constructor for exception org.jboss.cache.lock.LockingException
 
LockingException(Map) - Constructor for exception org.jboss.cache.lock.LockingException
 
LockingException(String) - Constructor for exception org.jboss.cache.lock.LockingException
 
LockingException(String, Map) - Constructor for exception org.jboss.cache.lock.LockingException
 
LockingException(String, Throwable) - Constructor for exception org.jboss.cache.lock.LockingException
 
LockingException(String, Throwable, Map) - Constructor for exception org.jboss.cache.lock.LockingException
 
lockInterruptibly() - Method in class org.jboss.cache.lock.SemaphoreLock
 
LockMap - Class in org.jboss.cache.lock
Provide lock ownership mapping.
LockMap() - Constructor for class org.jboss.cache.lock.LockMap
 
LockMap(Collection<Object>) - Constructor for class org.jboss.cache.lock.LockMap
This constructor is made available for testing with different collection types for the readOwners collection.
lockMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
lockMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
LockStrategy - Interface in org.jboss.cache.lock
Interface to specify lock strategy, e.g., for different isolation levels.
LockStrategyFactory - Class in org.jboss.cache.lock
Factory to create LockStragtegy instance.
LockStrategyFactory() - Constructor for class org.jboss.cache.lock.LockStrategyFactory
 
LockStrategyNone - Class in org.jboss.cache.lock
Transaction isolation level of None.
LockStrategyNone() - Constructor for class org.jboss.cache.lock.LockStrategyNone
 
LockStrategyReadCommitted - Class in org.jboss.cache.lock
Transaction isolation level of READ_COMMITTED.
LockStrategyReadCommitted() - Constructor for class org.jboss.cache.lock.LockStrategyReadCommitted
 
LockStrategyReadUncommitted - Class in org.jboss.cache.lock
Transaction isolation level of READ-UNCOMMITTED.
LockStrategyReadUncommitted() - Constructor for class org.jboss.cache.lock.LockStrategyReadUncommitted
 
LockStrategyRepeatableRead - Class in org.jboss.cache.lock
Transaction isolation level of Repeatable_Read.
LockStrategyRepeatableRead() - Constructor for class org.jboss.cache.lock.LockStrategyRepeatableRead
 
LockStrategySerializable - Class in org.jboss.cache.lock
Lock strategy of Serializable that prevents dirty read, non-repeatable read, and phantom read.
LockStrategySerializable() - Constructor for class org.jboss.cache.lock.LockStrategySerializable
 
LockUtil - Class in org.jboss.cache.lock
 
LockUtil() - Constructor for class org.jboss.cache.lock.LockUtil
 
log - Variable in class org.jboss.cache.config.ConfigurationComponent
 
log - Variable in class org.jboss.cache.factories.ComponentFactory
 
log - Variable in class org.jboss.cache.interceptors.Interceptor
 
log - Variable in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
log - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
log - Variable in class org.jboss.cache.statetransfer.DefaultStateTransferIntegrator
 
log - Static variable in class org.jboss.cache.statetransfer.StateTransferManager
 
log - Static variable in class org.jboss.cache.UnversionedNode
Debug log.
log_ - Static variable in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
lookup(Name) - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the named object.
lookup(String) - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the named object.
lookupLink(Name) - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the named object, following links except for the terminal atomic component of the name.
lookupLink(String) - Method in class org.jboss.cache.transaction.DummyContext
Retrieves the named object, following links except for the terminal atomic component of the name.
lookupMethod(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
lookupMethodId(Method) - Static method in class org.jboss.cache.marshall.MethodDeclarations
 
LRUAlgorithm - Class in org.jboss.cache.eviction
Least recently Used algorithm to purge old data.
LRUAlgorithm() - Constructor for class org.jboss.cache.eviction.LRUAlgorithm
 
LRUConfiguration - Class in org.jboss.cache.eviction
Configuration implementation for LRUPolicy.
LRUConfiguration() - Constructor for class org.jboss.cache.eviction.LRUConfiguration
 
LRUPolicy - Class in org.jboss.cache.eviction
Provider to provide eviction policy.
LRUPolicy() - Constructor for class org.jboss.cache.eviction.LRUPolicy
 
LRUQueue - Class in org.jboss.cache.eviction
LRU Eviction Queue implementation.

M

MAGICNUMBER_ARRAY_LIST - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_BOOLEAN - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_DEFAULT_DATA_VERSION - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_FQN - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_GRAVITATERESULT - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_GTX - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_HASH_MAP - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_HASH_SET - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_INTEGER - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_IPADDRESS - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_LINKED_LIST - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_LONG - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_MAPCOPY - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_MARSHALLEDVALUE - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_METHODCALL - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_NODEDATA - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_NODEDATA_EXCEPTION_MARKER - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_NODEDATA_MARKER - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_NULL - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_REF - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_SERIALIZABLE - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_SHORT - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_STRING - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_TREE_MAP - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
MAGICNUMBER_TREE_SET - Static variable in class org.jboss.cache.marshall.CacheMarshaller200
 
main(String[]) - Static method in class org.jboss.cache.ConsoleListener
The main method.
main(String[]) - Static method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
main(String[]) - Static method in class org.jboss.cache.Version
Prints version information.
main(String[]) - Static method in class org.jboss.cache.Version.Retro
 
ManagedConnectionFactory - Class in org.jboss.cache.loader
ManagedConnectionFactory for Application Server managed environments
ManagedConnectionFactory() - Constructor for class org.jboss.cache.loader.ManagedConnectionFactory
 
map - Variable in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
MapCopy<K,V> - Class in org.jboss.cache.util
Contains a fixed array of read-only map entries, from a copy of an existing map.
MapCopy(Map<K, V>) - Constructor for class org.jboss.cache.util.MapCopy
Copies the supplied map to an internal array.
MapCopy() - Constructor for class org.jboss.cache.util.MapCopy
 
markAsCreated() - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Marks the instance as having been created in the current transaction.
markAsCreated() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
markAsDeleted(boolean) - Method in class org.jboss.cache.AbstractNode
 
markAsDeleted(boolean, boolean) - Method in class org.jboss.cache.AbstractNode
 
markAsDeleted(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
markAsDeleted(boolean, boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
markAsDeleted(boolean) - Method in interface org.jboss.cache.NodeSPI
Marks the node as being deleted (or not) in the current transaction.
markAsDeleted(boolean, boolean) - Method in interface org.jboss.cache.NodeSPI
Same as NodeSPI.markAsDeleted(boolean) except that the option to recurse into children is provided.
markAsDeleted(boolean) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Marks the node as being deleted (or not) in the current transaction.
markAsDeleted(boolean, boolean) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Same as WorkspaceNode.markAsDeleted(boolean) except that the option to recurse into children is provided.
markAsDeleted(boolean, boolean) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
markAsResurrected(boolean) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Marks a node as resurrected, i.e., deleted and created again within the same transaction
markAsResurrected(boolean) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
markNodeCurrentlyInUse(Fqn, long) - Method in interface org.jboss.cache.Region
Marks a Node as currently in use, by adding an event to the eviction queue.
markNodeCurrentlyInUse(Fqn, long) - Method in class org.jboss.cache.RegionImpl
 
marshall(Object) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
marshallAssociatedState(Fqn, ObjectOutputStream) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
Does nothing in this base class; can be overridden in a subclass.
marshallDefaultDataVersion(DefaultDataVersion, ObjectOutputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
MarshalledValue - Class in org.jboss.cache.marshall
Wrapper that wraps cached data, providing lazy deserialization using the calling thread's context class loader.
MarshalledValue(Object) - Constructor for class org.jboss.cache.marshall.MarshalledValue
 
MarshalledValue() - Constructor for class org.jboss.cache.marshall.MarshalledValue
 
MarshalledValueHelper - Class in org.jboss.cache.marshall
Common functionality used by the MarshalledValueInterceptor and the MarshalledValueMap.
MarshalledValueHelper() - Constructor for class org.jboss.cache.marshall.MarshalledValueHelper
 
MarshalledValueInterceptor - Class in org.jboss.cache.interceptors
Interceptor that handles the wrapping and unwrapping of cached data using MarshalledValues.
MarshalledValueInterceptor() - Constructor for class org.jboss.cache.interceptors.MarshalledValueInterceptor
 
MarshalledValueMap - Class in org.jboss.cache.marshall
A Map that is able to wrap/unwrap MarshalledValues in keys or values.
MarshalledValueMap() - Constructor for class org.jboss.cache.marshall.MarshalledValueMap
 
MarshalledValueMap(Map) - Constructor for class org.jboss.cache.marshall.MarshalledValueMap
 
Marshaller - Interface in org.jboss.cache.marshall
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
MarshallingException - Exception in org.jboss.cache.marshall
Thrown when there is an exception in marshalling.
MarshallingException() - Constructor for exception org.jboss.cache.marshall.MarshallingException
 
MarshallingException(String) - Constructor for exception org.jboss.cache.marshall.MarshallingException
 
MarshallingException(String, Throwable) - Constructor for exception org.jboss.cache.marshall.MarshallingException
 
marshallTransientState(NodeSPI, ObjectOutputStream) - Method in class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
Do a preorder traversal: visit the node first, then the node's children
MarshallUtil - Class in org.jboss.cache.marshall
Utility methods related to marshalling and unmarshalling objects.
MarshallUtil() - Constructor for class org.jboss.cache.marshall.MarshallUtil
 
MBEAN_CLASS_SUFFIX - Static variable in class org.jboss.cache.jmx.JmxUtil
 
MethodCall - Class in org.jboss.cache.marshall
An extension of the JGroups MethodCall class.
MethodCall() - Constructor for class org.jboss.cache.marshall.MethodCall
 
MethodCall(Method, Object...) - Constructor for class org.jboss.cache.marshall.MethodCall
 
MethodCall(Method, int, Object...) - Constructor for class org.jboss.cache.marshall.MethodCall
 
MethodCallFactory - Class in org.jboss.cache.marshall
Factory class to create instances of org.jboss.cache.marshall.MethodCall
MethodCallFactory() - Constructor for class org.jboss.cache.marshall.MethodCallFactory
 
MethodDeclarations - Class in org.jboss.cache.marshall
Class containing Method and Method id definitions as well methods allowing lookup operations both ways.
MethodDeclarations() - Constructor for class org.jboss.cache.marshall.MethodDeclarations
 
MethodDispacherInterceptor - Class in org.jboss.cache.interceptors
The purpose of this interceptor is to supply a nicer way of handling the interception of desired methods: - one can regiter to be notified on an particular method call by extending handleCalledMethod method.
MethodDispacherInterceptor() - Constructor for class org.jboss.cache.interceptors.MethodDispacherInterceptor
 
MinMapUtil - Class in org.jboss.cache.util
Minimizes Map memory usage by changing the map instance based on the number of stored entries.
MissingPolicyException - Exception in org.jboss.cache.config
 
MissingPolicyException(String) - Constructor for exception org.jboss.cache.config.MissingPolicyException
 
Modification - Class in org.jboss.cache
Represents a modification in the cache.
Modification() - Constructor for class org.jboss.cache.Modification
Constructs a new modification.
Modification(Modification.ModificationType, Fqn, Object, Object) - Constructor for class org.jboss.cache.Modification
Constructs a new modification with details.
Modification(Modification.ModificationType, Fqn, Object) - Constructor for class org.jboss.cache.Modification
Constructs a new modification with key.
Modification(Modification.ModificationType, Fqn, Map) - Constructor for class org.jboss.cache.Modification
Constructs a new modification with data map.
Modification(Modification.ModificationType, Fqn) - Constructor for class org.jboss.cache.Modification
Constructs a new modification with fqn only.
Modification(Modification.ModificationType, Fqn, Fqn) - Constructor for class org.jboss.cache.Modification
Constructs a new modification with fqn only.
Modification.ModificationType - Enum in org.jboss.cache
 
modifiedEntries - Variable in class org.jboss.cache.util.Util.MapModifications
 
modifyElementCount(int) - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
modifyElementCount(int) - Method in interface org.jboss.cache.eviction.EvictionQueue
 
modifyElementCount(int) - Method in class org.jboss.cache.eviction.FIFOQueue
 
modifyElementCount(int) - Method in class org.jboss.cache.eviction.LFUQueue
 
modifyElementCount(int) - Method in class org.jboss.cache.eviction.LRUQueue
 
modifyElementCount(int) - Method in class org.jboss.cache.eviction.MRUQueue
 
modifyElementCount(int) - Method in class org.jboss.cache.eviction.NullEvictionQueue
No-op
move(Fqn<?>, Fqn<?>) - Method in interface org.jboss.cache.Cache
Moves a part of the cache to a different subtree.
move(String, String) - Method in interface org.jboss.cache.Cache
Convenience method that takes in string representations of Fqns.
move(Fqn<?>, Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
move(String, String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
moveMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
moveMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
MRUAlgorithm - Class in org.jboss.cache.eviction
Most Recently Used Algorithm.
MRUAlgorithm() - Constructor for class org.jboss.cache.eviction.MRUAlgorithm
 
MRUConfiguration - Class in org.jboss.cache.eviction
Configuration for MRUPolicy.
MRUConfiguration() - Constructor for class org.jboss.cache.eviction.MRUConfiguration
 
MRUPolicy - Class in org.jboss.cache.eviction
Most Recently Used Policy.
MRUPolicy() - Constructor for class org.jboss.cache.eviction.MRUPolicy
 
MRUQueue - Class in org.jboss.cache.eviction
MRU Eviction Queue implementation.

N

NAME - Static variable in class org.jboss.cache.config.EvictionRegionConfig
 
NAME - Static variable in class org.jboss.cache.factories.XmlConfigurationParser
 
NAME - Static variable in class org.jboss.cache.xml.XmlHelper
The <name> attribute to an <attribute> tag.
needCreateBeforeStart() - Method in enum org.jboss.cache.CacheStatus
 
needMoreResponses() - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor.ResponseValidityFilter
 
needMoreResponses() - Method in class org.jboss.cache.loader.ClusteredCacheLoader.ResponseValidityFilter
 
needStopBeforeDestroy() - Method in enum org.jboss.cache.CacheStatus
 
needToDestroyFailedCache() - Method in enum org.jboss.cache.CacheStatus
 
needToReplaceMap(int, int) - Method in class org.jboss.cache.interceptors.MarshalledValueInterceptor
put(Map) contents should not be wrapped since the map will need to be iterated over.
newCondition() - Method in class org.jboss.cache.lock.SemaphoreLock
 
newerThan(DataVersion) - Method in interface org.jboss.cache.optimistic.DataVersion
Returns true if this is a newer version than other.
newerThan(DataVersion) - Method in class org.jboss.cache.optimistic.DefaultDataVersion
 
next - Variable in class org.jboss.cache.interceptors.Interceptor
 
nextInterceptor(InvocationContext) - Method in class org.jboss.cache.interceptors.Interceptor
Forwards the call to the nextInterceptor interceptor in the chain.
NextMemberBuddyLocator - Class in org.jboss.cache.buddyreplication
This buddy locator uses a next-in-line algorithm to select buddies for a buddy group.
NextMemberBuddyLocator() - Constructor for class org.jboss.cache.buddyreplication.NextMemberBuddyLocator
 
NextMemberBuddyLocatorConfig - Class in org.jboss.cache.buddyreplication
Type-specific configuration object for NextMemberBuddyLocator.
NextMemberBuddyLocatorConfig() - Constructor for class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
Default constructor.
NO_CLUSTER_PREFIX - Static variable in class org.jboss.cache.jmx.JmxUtil
 
noDataFound() - Static method in class org.jboss.cache.buddyreplication.GravitateResult
Factory method that creates a GravitateResult indicating that no data has been found.
Node<K,V> - Interface in org.jboss.cache
A Node is a named logical grouping of data in the JBoss Cache.
NodeActivated - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is activated.
NodeActivatedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeActivated.
nodeColumn - Variable in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
NodeCreated - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is created.
NodeCreatedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeCreated.
NodeData - Class in org.jboss.cache.marshall
Serializable representation of the data of a node (FQN and attributes)
NodeData() - Constructor for class org.jboss.cache.marshall.NodeData
 
NodeData(Fqn<?>) - Constructor for class org.jboss.cache.marshall.NodeData
 
NodeData(Fqn<?>, Map<?, ?>) - Constructor for class org.jboss.cache.marshall.NodeData
 
NodeData(String, Map<?, ?>) - Constructor for class org.jboss.cache.marshall.NodeData
 
NodeDataExceptionMarker - Class in org.jboss.cache.marshall
 
NodeDataExceptionMarker() - Constructor for class org.jboss.cache.marshall.NodeDataExceptionMarker
 
NodeDataExceptionMarker(Throwable, Object) - Constructor for class org.jboss.cache.marshall.NodeDataExceptionMarker
 
NodeDataMarker - Class in org.jboss.cache.marshall
 
NodeDataMarker() - Constructor for class org.jboss.cache.marshall.NodeDataMarker
 
NodeEntry - Class in org.jboss.cache.eviction
Value object used in queue
NodeEntry(Fqn) - Constructor for class org.jboss.cache.eviction.NodeEntry
 
NodeEntry(String) - Constructor for class org.jboss.cache.eviction.NodeEntry
 
NodeEvent - Interface in org.jboss.cache.notifications.event
Transactional events that additionally expose an Fqn as such events pertain to a specific node.
nodeEventQueueSize() - Method in interface org.jboss.cache.Region
Returns the size of the node event queue, used by the eviction thread.
nodeEventQueueSize() - Method in class org.jboss.cache.RegionImpl
 
NodeEventType - Enum in org.jboss.cache.eviction
Enumeration of the valid event types used to create an EvictedEventNode.
NodeEvicted - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is evicted.
NodeEvictedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeEvicted.
NodeFactory<K,V> - Class in org.jboss.cache
Generates new nodes based on the CacheSPI configuration.
NodeFactory(CacheSPI<K, V>) - Constructor for class org.jboss.cache.NodeFactory
Constructs an instance of the factory
NodeFactory() - Constructor for class org.jboss.cache.NodeFactory
 
NodeFactory.NodeType - Enum in org.jboss.cache
 
NodeInvocationDelegate<K,V> - Class in org.jboss.cache.invocation
The delegate that users (and interceptor authors) interact with when they obtain a node from the cache or another node.
NodeInvocationDelegate(UnversionedNode) - Constructor for class org.jboss.cache.invocation.NodeInvocationDelegate
 
NodeLoaded - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is loaded from a CacheLoader.
NodeLoadedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeLoaded.
NodeLock - Interface in org.jboss.cache.lock
Interface for a lock for nodes.
NodeLock.LockType - Enum in org.jboss.cache.lock
 
NodeModified - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node has been modified.
NodeModifiedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeModified
NodeModifiedEvent.ModificationType - Enum in org.jboss.cache.notifications.event
Different cache modification types.
NodeMoved - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is moved using the Cache.move(org.jboss.cache.Fqn,org.jboss.cache.Fqn) API.
NodeMovedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeMoved.
NodeNotExistsException - Exception in org.jboss.cache
Thrown when an operation is attempted on a non-existing node in the cache
NodeNotExistsException() - Constructor for exception org.jboss.cache.NodeNotExistsException
 
NodeNotExistsException(String) - Constructor for exception org.jboss.cache.NodeNotExistsException
 
NodeNotExistsException(String, Throwable) - Constructor for exception org.jboss.cache.NodeNotExistsException
 
NodeNotValidException - Exception in org.jboss.cache
Thrown whenever operations are attempted on a node that is no longer valid.
NodeNotValidException() - Constructor for exception org.jboss.cache.NodeNotValidException
 
NodeNotValidException(Throwable) - Constructor for exception org.jboss.cache.NodeNotValidException
 
NodeNotValidException(String) - Constructor for exception org.jboss.cache.NodeNotValidException
 
NodeNotValidException(String, Throwable) - Constructor for exception org.jboss.cache.NodeNotValidException
 
NodePassivated - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is passivated.
NodePassivatedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodePassivated.
NodeRemoved - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is removed from the cache.
NodeRemovedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeRemoved.
NodeSPI<K,V> - Interface in org.jboss.cache
A more detailed interface to Node, which is used when writing plugins for or extending JBoss Cache.
NodeVisited - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when a node is visited.
NodeVisitedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with NodeVisited.
NonBlockingWriterLock - Class in org.jboss.cache.lock
NonBlockingWriterLock is a read/write lock (with upgrade) that has non-blocking write lock acquisition on existing read lock(s).
NonBlockingWriterLock() - Constructor for class org.jboss.cache.lock.NonBlockingWriterLock
 
NOTIF_CACHE_STARTED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_CACHE_STOPPED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_ACTIVATED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_CREATED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_EVICTED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_LOADED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_MODIFIED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_MOVED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_PASSIVATED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_REMOVED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_NODE_VISITED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NOTIF_VIEW_CHANGED - Static variable in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
 
NotificationInterceptor - Class in org.jboss.cache.interceptors
The interceptor in charge of firing off notifications to cache listeners
NotificationInterceptor() - Constructor for class org.jboss.cache.interceptors.NotificationInterceptor
 
Notifier - Class in org.jboss.cache.notifications
Helper class that handles all notifications to registered listeners.
Notifier() - Constructor for class org.jboss.cache.notifications.Notifier
 
Notifier(Cache) - Constructor for class org.jboss.cache.notifications.Notifier
 
notifyAfterCompletion(int) - Method in class org.jboss.cache.transaction.DummyTransaction
 
notifyBeforeCompletion() - Method in class org.jboss.cache.transaction.DummyTransaction
 
notifyBuddyGroupChange(BuddyGroup, boolean) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a buddy group change event.
notifyCacheBlocked(CacheSPI, boolean) - Method in class org.jboss.cache.notifications.Notifier
 
notifyCacheStarted(CacheSPI, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a cacheStarted event.
notifyCacheStopped(CacheSPI, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a cacheStopped event.
notifyCacheUnblocked(CacheSPI, boolean) - Method in class org.jboss.cache.notifications.Notifier
 
notifyNodeActivated(Fqn, boolean, Map, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeActivated event.
notifyNodeCreated(Fqn, boolean, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeCreated event.
notifyNodeEvicted(Fqn, boolean, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeEvicted event.
notifyNodeLoaded(Fqn, boolean, Map, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeLoaded event.
notifyNodeModified(Fqn, boolean, NodeModifiedEvent.ModificationType, Map, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeModified event.
notifyNodeMoved(Fqn, Fqn, boolean, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
 
notifyNodePassivated(Fqn, boolean, Map, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodePassivated event.
notifyNodeRemoved(Fqn, boolean, Map, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeRemoved event.
notifyNodeVisited(Fqn, boolean, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a nodeVisited event.
notifyTransactionCompleted(Transaction, boolean, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a transaction completion event.
notifyTransactionRegistered(Transaction, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a transaction registration event.
notifyViewChange(View, InvocationContext) - Method in class org.jboss.cache.notifications.Notifier
Notifies all registered listeners of a viewChange event.
NULL - Static variable in class org.jboss.cache.interceptors.ActivationInterceptor
 
NULL_NODE_IN_ROW - Static variable in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
NullEvictionAlgorithm - Class in org.jboss.cache.eviction
Algorithm for NullEvictionPolicy.
NullEvictionPolicy - Class in org.jboss.cache.eviction
Eviction policy that does nothing and always tells the eviction interceptor an event can be ignored, saving the overhead of constructing and processing event objects.
NullEvictionPolicy() - Constructor for class org.jboss.cache.eviction.NullEvictionPolicy
Constructs a new NullEvictionPolicy.
NullEvictionPolicyConfig - Class in org.jboss.cache.eviction
Configuration class for NullEvictionPolicy.
NullEvictionPolicyConfig() - Constructor for class org.jboss.cache.eviction.NullEvictionPolicyConfig
Constructs a new NullEvictionPolicyConfig.
NullEvictionQueue - Class in org.jboss.cache.eviction
A queue that does nothing.

O

objectFromByteBuffer(byte[]) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
objectFromByteBuffer(byte[]) - Static method in class org.jboss.cache.marshall.MarshallUtil
Creates an object from a byte buffer using MarshalledValueInputStream.
objectFromByteBuffer(InputStream) - Static method in class org.jboss.cache.marshall.MarshallUtil
Creates an object from a byte buffer using MarshalledValueInputStream.
objectFromByteBuffer(byte[]) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
objectFromObjectStream(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
objectFromObjectStream(ObjectInputStream) - Method in interface org.jboss.cache.marshall.Marshaller
Unmarshalls an object from an ObjectInputStream
objectFromObjectStream(ObjectInputStream) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
objectFromObjectStreamRegionBased(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
objectFromStream(InputStream) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
objectFromStream(InputStream) - Method in interface org.jboss.cache.marshall.Marshaller
Unmarshalls an object from an InputStream
objectFromStream(InputStream) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
ObjectStreamPool - Class in org.jboss.cache.marshall.io
A stream pool
ObjectStreamPool() - Constructor for class org.jboss.cache.marshall.io.ObjectStreamPool
 
objectToByteBuffer(Object) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, boolean) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, boolean) - Method in interface org.jboss.cache.marshall.Marshaller
Same as RpcDispatcher.Marshaller.objectToByteBuffer(Object) except that you can optionally specify to write object stream headers.
objectToByteBuffer(Object) - Static method in class org.jboss.cache.marshall.MarshallUtil
Serializes an object into a byte buffer using MarshalledValueOutputStream.
objectToByteBuffer(Object, boolean) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
objectToObjectStream(Object, ObjectOutputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
objectToObjectStream(Object, ObjectOutputStream, Fqn) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
objectToObjectStream(Object, ObjectOutputStream) - Method in interface org.jboss.cache.marshall.Marshaller
Marshalls an object to a given ObjectOutputStream
objectToObjectStream(Object, ObjectOutputStream, Fqn) - Method in interface org.jboss.cache.marshall.Marshaller
Overloaded form of Marshaller.objectToObjectStream(Object,java.io.ObjectOutputStream) which adds a hint to the Fqn region
objectToObjectStream(Object, ObjectOutputStream, Fqn) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
objectToObjectStream(Object, ObjectOutputStream) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
open() - Method in class org.jboss.cache.util.ThreadGate
Open the gate.
optimisedIterator(List<MethodCall>) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
Removes non-crud methods, plus clobs together common calls to Fqn's.
optimistic - Variable in class org.jboss.cache.interceptors.InvalidationInterceptor
 
OptimisticCreateIfNotExistsInterceptor - Class in org.jboss.cache.interceptors
Used to create new NodeSPI instances in the main data structure and then copy it into the TransactionWorkspace as WorkspaceNodes as needed.
OptimisticCreateIfNotExistsInterceptor() - Constructor for class org.jboss.cache.interceptors.OptimisticCreateIfNotExistsInterceptor
 
OptimisticInterceptor - Class in org.jboss.cache.interceptors
Abstract interceptor for optimistic locking
OptimisticInterceptor() - Constructor for class org.jboss.cache.interceptors.OptimisticInterceptor
 
OptimisticLockingInterceptor - Class in org.jboss.cache.interceptors
Locks nodes during transaction boundaries.
OptimisticLockingInterceptor() - Constructor for class org.jboss.cache.interceptors.OptimisticLockingInterceptor
 
OptimisticNodeInterceptor - Class in org.jboss.cache.interceptors
Operations on nodes are done on the copies that exist in the workspace rather than passed down to the CallInterceptor.
OptimisticNodeInterceptor() - Constructor for class org.jboss.cache.interceptors.OptimisticNodeInterceptor
 
optimisticPrepare(GlobalTransaction, List, Map, Address, boolean) - Method in class org.jboss.cache.CacheImpl
Throws UnsupportedOperationException.
optimisticPrepareMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
optimisticPrepareMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
OptimisticReplicationInterceptor - Class in org.jboss.cache.interceptors
Replication interceptor for the optimistically locked interceptor chain.
OptimisticReplicationInterceptor() - Constructor for class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
OptimisticTransactionEntry - Class in org.jboss.cache.transaction
Subclasses the TransactionEntry class to add a TransactionWorkspace.
OptimisticTransactionEntry(Transaction) - Constructor for class org.jboss.cache.transaction.OptimisticTransactionEntry
 
OptimisticValidatorInterceptor - Class in org.jboss.cache.interceptors
Validates the data in the TransactionWorkspace against data in the underlying data structure (versions only) and then applies changes to the underlying data structure.
OptimisticValidatorInterceptor() - Constructor for class org.jboss.cache.interceptors.OptimisticValidatorInterceptor
 
Option - Class in org.jboss.cache.config
Used to override characteristics of specific calls to the cache.
Option() - Constructor for class org.jboss.cache.config.Option
 
OrderedSynchronizationHandler - Class in org.jboss.cache.interceptors
Maintains a list of Synchronization handlers.
OrderedSynchronizationHandler(Transaction) - Constructor for class org.jboss.cache.interceptors.OrderedSynchronizationHandler
 
org.jboss.cache - package org.jboss.cache
 
org.jboss.cache.buddyreplication - package org.jboss.cache.buddyreplication
 
org.jboss.cache.cluster - package org.jboss.cache.cluster
 
org.jboss.cache.config - package org.jboss.cache.config
 
org.jboss.cache.eviction - package org.jboss.cache.eviction
 
org.jboss.cache.factories - package org.jboss.cache.factories
 
org.jboss.cache.factories.annotations - package org.jboss.cache.factories.annotations
 
org.jboss.cache.interceptors - package org.jboss.cache.interceptors
 
org.jboss.cache.invocation - package org.jboss.cache.invocation
 
org.jboss.cache.jmx - package org.jboss.cache.jmx
 
org.jboss.cache.loader - package org.jboss.cache.loader
 
org.jboss.cache.loader.bdbje - package org.jboss.cache.loader.bdbje
 
org.jboss.cache.loader.jdbm - package org.jboss.cache.loader.jdbm
 
org.jboss.cache.loader.tcp - package org.jboss.cache.loader.tcp
 
org.jboss.cache.lock - package org.jboss.cache.lock
 
org.jboss.cache.marshall - package org.jboss.cache.marshall
 
org.jboss.cache.marshall.io - package org.jboss.cache.marshall.io
 
org.jboss.cache.notifications - package org.jboss.cache.notifications
 
org.jboss.cache.notifications.annotation - package org.jboss.cache.notifications.annotation
 
org.jboss.cache.notifications.event - package org.jboss.cache.notifications.event
 
org.jboss.cache.optimistic - package org.jboss.cache.optimistic
 
org.jboss.cache.remoting.jgroups - package org.jboss.cache.remoting.jgroups
 
org.jboss.cache.statetransfer - package org.jboss.cache.statetransfer
 
org.jboss.cache.transaction - package org.jboss.cache.transaction
 
org.jboss.cache.util - package org.jboss.cache.util
 
org.jboss.cache.util.concurrent - package org.jboss.cache.util.concurrent
 
org.jboss.cache.util.reflect - package org.jboss.cache.util.reflect
 
org.jboss.cache.xml - package org.jboss.cache.xml
 
originLocal - Variable in class org.jboss.cache.invocation.AbstractInvocationDelegate
 
OWNER_ANY - Static variable in class org.jboss.cache.lock.LockMap
 
OWNER_READ - Static variable in class org.jboss.cache.lock.LockMap
 
OWNER_WRITE - Static variable in class org.jboss.cache.lock.LockMap
 
OwnerNotExistedException - Exception in org.jboss.cache.lock
 
OwnerNotExistedException() - Constructor for exception org.jboss.cache.lock.OwnerNotExistedException
 
OwnerNotExistedException(String) - Constructor for exception org.jboss.cache.lock.OwnerNotExistedException
 
OwnerNotExistedException(String, Throwable) - Constructor for exception org.jboss.cache.lock.OwnerNotExistedException
 
OwnerNotExistedException(Throwable) - Constructor for exception org.jboss.cache.lock.OwnerNotExistedException
 

P

parseBuddyReplicationConfig(Element) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
parseCacheLoaderConfig(Element) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
parseClusterConfigXml(Element) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
Parses the cluster config which is used to start a JGroups channel
parseConfigs(String) - Method in class org.jboss.cache.factories.CacheConfigsXmlParser
 
parseConfigs(InputStream) - Method in class org.jboss.cache.factories.CacheConfigsXmlParser
 
parseConfiguration(Element) - Method in class org.jboss.cache.factories.XmlConfigurationParser
 
parseEvictionConfig(Element) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
parseEvictionPolicyConfig(Element, EvictionPolicyConfig) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
parseEvictionRegionConfig(Element, String, int) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
parseFile(String) - Method in class org.jboss.cache.factories.XmlConfigurationParser
Parses an XML file and returns a new configuration.
parseStream(InputStream) - Method in class org.jboss.cache.factories.XmlConfigurationParser
Parses an input stream containing XML text and returns a new configuration.
PARTIAL_STATE_DELIMITER - Static variable in class org.jboss.cache.statetransfer.StateTransferManager
 
participants - Variable in class org.jboss.cache.transaction.DummyTransaction
 
passCacheToChildConfig(ConfigurationComponent) - Method in class org.jboss.cache.config.ConfigurationComponent
 
PassivationInterceptor - Class in org.jboss.cache.interceptors
Writes evicted nodes back to the store on the way in through the CacheLoader, either before each method call (no TXs), or at TX commit.
PassivationInterceptor() - Constructor for class org.jboss.cache.interceptors.PassivationInterceptor
 
PassivationInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing passivation statistics
PATH_PATTERN - Static variable in class org.jboss.cache.loader.FileCacheLoader
For full path, check '*' '<' '>' '|' '"' '?'
peek(Fqn<?>, boolean) - Method in class org.jboss.cache.CacheImpl
 
peek(Fqn<?>, boolean, boolean) - Method in class org.jboss.cache.CacheImpl
 
peek(Fqn<?>, boolean) - Method in interface org.jboss.cache.CacheSPI
Returns a node without accessing the interceptor chain.
peek(Fqn<?>, boolean, boolean) - Method in interface org.jboss.cache.CacheSPI
Returns a node without accessing the interceptor chain, optionally returning nodes that are marked as invalid (Node.isValid() == false).
peek(Fqn, boolean, boolean) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
peek(Fqn, boolean) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
peekElements() - Method in class org.jboss.cache.Fqn
Peeks into the elements that build up this Fqn.
peekNode(InvocationContext, Fqn, boolean, boolean, boolean) - Method in class org.jboss.cache.interceptors.Interceptor
First checks the invocation context for previously obtained reference to a node, if this doesn't exist, performs a cache.peek() and holds on to the node reference.
PessimisticLockInterceptor - Class in org.jboss.cache.interceptors
An interceptor that handles locking.
PessimisticLockInterceptor() - Constructor for class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
PLAIN_CACHE_TYPE - Static variable in class org.jboss.cache.jmx.JmxUtil
 
populateFromBaseConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
postDeregister() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Unregisters the interceptors, if CacheJmxWrapper.getRegisterInterceptors() is true.
postRegister(Boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Registers the cache's interceptors, if CacheJmxWrapper.getRegisterInterceptors() is true.
preDeregister() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
No-op.
PREFIX - Static variable in class org.jboss.cache.jmx.JmxUtil
 
preload(Fqn, boolean, boolean) - Method in class org.jboss.cache.loader.CacheLoaderManager
Preloads a specific Fqn into the cache from the configured cacheloader
preloadCache() - Method in class org.jboss.cache.loader.CacheLoaderManager
Performs a preload on the cache based on the cache loader preload configs used when configuring the cache.
prepare(GlobalTransaction, List, Address, boolean) - Method in class org.jboss.cache.CacheImpl
Throws UnsupportedOperationException.
prepare(Object, List<Modification>, boolean) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
prepare(Object, List<Modification>, boolean) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
prepare(Object, List<Modification>, boolean) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
First phase in transaction commit process.
prepare(Object, List<Modification>, boolean) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Begins a transaction and applies the given modifications.
prepare(Object, List<Modification>, boolean) - Method in interface org.jboss.cache.loader.CacheLoader
Prepares a list of modifications.
prepare(Object, List, boolean) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Prepare the modifications.
prepare(Object, List, boolean) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing.
prepare(Object) - Method in interface org.jboss.cache.loader.ConnectionFactory
 
prepare(Object) - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
prepare(Object, List<Modification>, boolean) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
prepare(Object, List<Modification>, boolean) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
prepareMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
prepareMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
preRegister(MBeanServer, ObjectName) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Caches the provided server and objName.
print(StringBuffer, int) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
print(StringBuffer, int) - Method in interface org.jboss.cache.NodeSPI
Deprecated. 
printCacheDetails() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
printCacheDetails() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
printCacheDetails(Cache) - Static method in class org.jboss.cache.util.CachePrinter
Prints the contents of the cache (nodes + data) to a string
printCacheDetailsAsHtml() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
printCacheDetailsAsHtml() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
printCacheInterceptors(CacheSPI<?, ?>) - Static method in class org.jboss.cache.util.CachePrinter
 
printCacheLockingInfo(Cache) - Static method in class org.jboss.cache.util.CachePrinter
Prints the status of locks in the cache (nodes + locks) to a string
printConfigurationAsHtmlString() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
printConfigurationAsHtmlString() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
printConfigurationAsString() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
printConfigurationAsString() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
printDetails() - Method in class org.jboss.cache.CacheImpl
Prints information about the contents of the nodes in the cache's current in-memory state.
printDetails(Event) - Method in class org.jboss.cache.ConsoleListener
 
printDetails(StringBuffer, int) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
printDetails(StringBuffer, int) - Method in interface org.jboss.cache.NodeSPI
Prints details of this node to the StringBuffer passed in.
printDetails(StringBuffer, int) - Method in class org.jboss.cache.UnversionedNode
 
printDetailsWithFqn(NodeEvent) - Method in class org.jboss.cache.ConsoleListener
 
printInfo() - Method in class org.jboss.cache.lock.LockMap
Debugging information.
printInterceptorChain(Interceptor) - Static method in class org.jboss.cache.util.CachePrinter
 
printLockInfo() - Method in class org.jboss.cache.CacheImpl
Returns lock information.
printLockInfo() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
printLockInfo() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
printLockInfo(StringBuffer, int) - Method in class org.jboss.cache.lock.IdentityLock
 
printLockInfo(StringBuffer, int) - Method in interface org.jboss.cache.lock.NodeLock
 
printLockInfoAsHtml() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
printLockInfoAsHtml() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
printMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
printMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
printNewView(ViewChangedEvent) - Method in class org.jboss.cache.ConsoleListener
 
printVersion() - Static method in class org.jboss.cache.Version
Returns version information as a string.
printVersionId(byte[], int) - Static method in class org.jboss.cache.Version
 
printVersionId(byte[]) - Static method in class org.jboss.cache.Version
 
process(Region) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Process the given region.
process(Region) - Method in class org.jboss.cache.eviction.BaseSortedEvictionAlgorithm
 
process(Region) - Method in interface org.jboss.cache.eviction.EvictionAlgorithm
Entry point for evictin algorithm.
process(Region) - Method in class org.jboss.cache.eviction.NullEvictionAlgorithm
No-op
processAddedElement(EvictedEventNode) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
processAddedNodes(EvictedEventNode) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Convenience method, which calls BaseEvictionAlgorithm.processAddedNodes(EvictedEventNode, int, boolean) using values in the evictedEventNode for number of added elements and the resetElementCount flag.
processAddedNodes(EvictedEventNode, int, boolean) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
processConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
processConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.JDBCCacheLoader
Builds a AdjListJDBCCacheLoaderConfig based on the supplied base config.
processConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated.  
processMarkInUseNodes(Fqn, long) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
processQueues(Region) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Event processing for Evict/Add/Visiting of nodes.
processQueues(Region) - Method in class org.jboss.cache.eviction.BaseSortedEvictionAlgorithm
 
processQueues(Region) - Method in class org.jboss.cache.eviction.ExpirationAlgorithm
 
processRemovedElement(EvictedEventNode) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
processRemovedNodes(EvictedEventNode) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Remove a node from cache.
processUnmarkInUseNodes(Fqn) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
processVisitedNodes(EvictedEventNode) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Visit a node in cache.
processVisitedNodes(EvictedEventNode) - Method in class org.jboss.cache.eviction.MRUAlgorithm
 
prune() - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
prune() - Method in class org.jboss.cache.eviction.ElementSizeAlgorithm
 
prune() - Method in class org.jboss.cache.eviction.ExpirationAlgorithm
 
prune() - Method in class org.jboss.cache.eviction.LFUAlgorithm
 
prune() - Method in class org.jboss.cache.eviction.LRUAlgorithm
 
purgeIfNecessary() - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
purgeLoaders(boolean) - Method in class org.jboss.cache.loader.CacheLoaderManager
 
pushState(NodeSPI) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Pushes the state of a specific node by reading the node's data from the cache and putting in the cache store via the cache loader.
put(Fqn<?>, K, V) - Method in interface org.jboss.cache.Cache
Associates the specified value with the specified key for a Node in this cache.
put(String, K, V) - Method in interface org.jboss.cache.Cache
Convenience method that takes a string representation of an Fqn.
put(Fqn<?>, Map<K, V>) - Method in interface org.jboss.cache.Cache
Copies all of the mappings from the specified map to a Node.
put(String, Map<K, V>) - Method in interface org.jboss.cache.Cache
Convenience method that takes a string representation of an Fqn.
put(Fqn<?>, Map<K, V>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
put(String, Map<K, V>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
put(Fqn<?>, K, V) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
put(String, K, V) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
put(K, V) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
put(Fqn, Map<Object, Object>, boolean) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
put(List<Modification>) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
put(Fqn, Map) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
put(List<Modification>) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
put(Fqn, Map) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
put(List<Modification>) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Stores a single FQN-key-value record.
put(Fqn, Map) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Stores a map of key-values for a given FQN, but does not delete existing key-value pairs (that is, it does not erase).
put(List<Modification>) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Applies the given modifications.
put(Fqn, Object, Object) - Method in interface org.jboss.cache.loader.CacheLoader
Puts a key and value into the attribute map of a given node.
put(Fqn, Map<Object, Object>) - Method in interface org.jboss.cache.loader.CacheLoader
Puts all entries of the map into the existing map of the given node, overwriting existing keys, but not clearing the existing map before insertion.
put(List<Modification>) - Method in interface org.jboss.cache.loader.CacheLoader
Applies all modifications to the backend store.
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Inserts key and value into the attributes hashmap of the given node.
put(Fqn, Map) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Inserts all elements of attributes into the attributes hashmap of the given node, overwriting existing attributes, but not clearing the existing hashmap before insertion (making it a union of existing and new attributes) If the node does not exist, all parent nodes from the root down are created automatically
put(List<Modification>) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Inserts all modifications to the backend store.
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
put(Fqn, Map) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing; replication handles put.
put(List<Modification>) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing; replication handles put.
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.FileCacheLoader
 
put(Fqn, Map) - Method in class org.jboss.cache.loader.FileCacheLoader
 
put(Fqn, Map, boolean) - Method in class org.jboss.cache.loader.FileCacheLoader
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.JDBCCacheLoader
As per interface's contract.
put(Fqn, Map) - Method in class org.jboss.cache.loader.JDBCCacheLoader
As per interface's contract.
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated. Adds/overrides a value in a node for a key.
put(Fqn, Map) - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated. Adds attributes from the passed in map to the existing node.
put(Fqn, Map, boolean) - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated.  
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Stores a single FQN-key-value record.
put(Fqn, Map) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Stores a map of key-values for a given FQN, but does not delete existing key-value pairs (that is, it does not erase).
put(List<Modification>) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Applies the given modifications.
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
put(Fqn, Map<Object, Object>) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
put(Fqn, Map) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
put(List<Modification>) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
put(Fqn, Map) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
put(List<Modification>) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
PUT - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
put(Fqn, Map<Object, Object>) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
put(List<Modification>) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
put(K, V) - Method in class org.jboss.cache.lock.ThreadLocalMap
 
put(Object, Object) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
put(K, V) - Method in interface org.jboss.cache.Node
Associates the specified value with the specified key for this node.
put(K, V) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
put(Transaction, GlobalTransaction) - Method in class org.jboss.cache.transaction.TransactionTable
Associates the global transaction with the local transaction.
put(GlobalTransaction, TransactionEntry) - Method in class org.jboss.cache.transaction.TransactionTable
Associates the global transaction with a transaction entry.
put(Object, Object) - Method in class org.jboss.cache.UnversionedNode
 
put(K, V) - Method in class org.jboss.cache.util.DeltaMap
 
put(Map<K, V>, K, V) - Static method in class org.jboss.cache.util.MinMapUtil
Puts a mapping into a map, returns a map with the mapping.
PUT_KEY_VAL - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
PUT_LIST - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
putAll(Map<K, V>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
putAll(Map<? extends K, ? extends V>) - Method in class org.jboss.cache.lock.ThreadLocalMap
 
putAll(Map) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
putAll(Map<K, V>) - Method in interface org.jboss.cache.Node
Copies all of the mappings from the specified map to this node's map.
putAll(Map<K, V>) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
putAll(Map) - Method in class org.jboss.cache.UnversionedNode
 
putAll(Map<K, V>, Map<K, V>) - Static method in class org.jboss.cache.util.MinMapUtil
Puts a number of entries into a map, returns a map.
putAllDirect(Map<K, V>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
putAllDirect(Map<K, V>) - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.putAll(Map) except that it operates directly on the node and bypasses the interceptor chain.
putAllDirect(Map) - Method in class org.jboss.cache.UnversionedNode
 
putCallOnAsyncReplicationQueue(MethodCall) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
putDataEraseMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataEraseMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataEraseVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataEraseVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDataVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putDirect(K, V) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
putDirect(K, V) - Method in interface org.jboss.cache.NodeSPI
Functionally the same as Node.put(Object,Object) except that it operates directly on the node and bypasses the interceptor chain.
putDirect(Object, Object) - Method in class org.jboss.cache.UnversionedNode
 
putForExternalRead(Fqn<?>, K, V) - Method in interface org.jboss.cache.Cache
Under special operating behavior, associates the value with the specified key for a node identified by the Fqn passed in.
putForExternalRead(Fqn<?>, K, V) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
putForExternalReadMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putForExternalReadMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putForExternalReadVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putForExternalReadVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putIfAbsent(K, V) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
putIfAbsent(K, V) - Method in interface org.jboss.cache.Node
If the specified key is not already associated with a value, associate it with the given value, and returns the Object (if any) that occupied the space, or null.
putIfAbsent(K, V) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
putKeyValMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putKeyValMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putKeyValVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putKeyValVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
putNodeEvent(EvictedEventNode) - Method in interface org.jboss.cache.Region
Adds an EvictedEventNode to the internal queue for processing by the eviction thread.
putNodeEvent(EvictedEventNode) - Method in class org.jboss.cache.RegionImpl
 
putReferencedObject(int, Object) - Method in class org.jboss.cache.marshall.UnmarshalledReferences
Adds a referenced object to the list of references

R

raw - Variable in class org.jboss.cache.marshall.MarshalledValue
 
readBooleanAttribute(Element, String, String, boolean) - Static method in class org.jboss.cache.xml.XmlHelper
Retrieves the boolean value of a given attribute for the first encountered instance of elementName
readBooleanContents(Element, String) - Static method in class org.jboss.cache.xml.XmlHelper
Similar to XmlHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readBooleanContents(Element, String, boolean) - Static method in class org.jboss.cache.xml.XmlHelper
Similar to XmlHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readerLock_ - Variable in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
readerOwners() - Method in class org.jboss.cache.lock.LockMap
Returns an unmodifiable set of reader owner objects.
readExternal(ObjectInput) - Method in class org.jboss.cache.Fqn
 
readExternal(ObjectInput) - Method in class org.jboss.cache.marshall.MarshalledValue
 
readExternal(ObjectInput) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
readExternal(ObjectInput) - Method in class org.jboss.cache.marshall.NodeData
 
readExternal(ObjectInput) - Method in class org.jboss.cache.marshall.NodeDataExceptionMarker
 
readExternal(ObjectInput) - Method in class org.jboss.cache.Modification
Reads data from an external stream.
readExternal(ObjectInput) - Method in class org.jboss.cache.transaction.GlobalTransaction
 
readLock() - Method in interface org.jboss.cache.lock.LockStrategy
Return a read lock object.
readLock() - Method in class org.jboss.cache.lock.LockStrategyNone
 
readLock() - Method in class org.jboss.cache.lock.LockStrategyReadCommitted
 
readLock() - Method in class org.jboss.cache.lock.LockStrategyReadUncommitted
 
readLock() - Method in class org.jboss.cache.lock.LockStrategyRepeatableRead
 
readLock() - Method in class org.jboss.cache.lock.LockStrategySerializable
 
readLock() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
readLock() - Method in class org.jboss.cache.lock.SimpleLock
 
ReadOnlyDelegatingCacheLoader - Class in org.jboss.cache.loader
Provides ignoreModifications features to all cache loaders.
ReadOnlyDelegatingCacheLoader(CacheLoader) - Constructor for class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
readPropertiesContents(Element, String) - Static method in class org.jboss.cache.xml.XmlHelper
Reads the contents of a named sub element within a given element, and attempts to parse the contents as a Java properties file.
readReference(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
Reads a reference from a given stream.
readReference(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller210
This version of readReference is written to solve JBCACHE-1211, where references are encoded as ints rather than shorts.
readStringContents(Element, String) - Static method in class org.jboss.cache.xml.XmlHelper
Reads the contents of the first occurence of elementName under the given element, trimming results of whitespace.
readUnsignedInt(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
readUnsignedInt(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller210
Reads an int stored in variable-length format.
readUnsignedLong(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
readUnsignedLong(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller210
Reads an int stored in variable-length format.
ReadWriteLockWithUpgrade - Class in org.jboss.cache.lock
This class is similar to PreferredWriterReadWriteLock except that the read lock is upgradable to write lock.
ReadWriteLockWithUpgrade() - Constructor for class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
ReadWriteLockWithUpgrade.ReaderLock - Class in org.jboss.cache.lock
 
ReadWriteLockWithUpgrade.ReaderLock() - Constructor for class org.jboss.cache.lock.ReadWriteLockWithUpgrade.ReaderLock
 
ReadWriteLockWithUpgrade.WriterLock - Class in org.jboss.cache.lock
 
ReadWriteLockWithUpgrade.WriterLock() - Constructor for class org.jboss.cache.lock.ReadWriteLockWithUpgrade.WriterLock
 
realRemove(Fqn, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method; not to be used externally.
rebind(Name, Object) - Method in class org.jboss.cache.transaction.DummyContext
Binds a name to an object, overwriting any existing binding.
rebind(String, Object) - Method in class org.jboss.cache.transaction.DummyContext
Binds a name to an object, overwriting any existing binding.
receive(Message) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
Callback, does nothing.
recordNodeLock(GlobalTransaction, NodeLock) - Method in class org.jboss.cache.transaction.TransactionTable
Add the lock to the list of locks maintained for this transaction (needed for release of locks on commit or rollback)
recycleQueue - Variable in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Contains Fqn instances.
ReflectionUtil - Class in org.jboss.cache.util.reflect
Basic reflection utilities to enhance what the JDK provides.
ReflectionUtil() - Constructor for class org.jboss.cache.util.reflect.ReflectionUtil
 
REGION - Static variable in class org.jboss.cache.config.EvictionRegionConfig
 
region - Variable in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Mapped region.
Region - Interface in org.jboss.cache
Defines characteristics such as class loading and eviction of Nodes belonging to a Region in a Cache.
Region.Status - Enum in org.jboss.cache
Region status
Region.Type - Enum in org.jboss.cache
Types of regions.
REGION_POLICY_CLASS - Static variable in class org.jboss.cache.config.EvictionRegionConfig
 
regionalizedMethodCallFromByteBuffer(byte[]) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
regionalizedMethodCallFromByteBuffer(byte[]) - Method in interface org.jboss.cache.marshall.Marshaller
Returns a RegionalizedMethodCall from a byte buffer.
regionalizedMethodCallFromByteBuffer(byte[]) - Method in class org.jboss.cache.marshall.VersionAwareMarshaller
 
regionalizedMethodCallFromObjectStream(ObjectInputStream) - Method in class org.jboss.cache.marshall.AbstractMarshaller
 
regionalizedMethodCallFromObjectStream(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
regionalizedMethodCallFromObjectStream(ObjectInputStream) - Method in interface org.jboss.cache.marshall.Marshaller
Returns a RegionalizedMethodCall from an object input stream.
regionAwareMarshall(Fqn, Object) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
regionAwareUnmarshall(Fqn, Object) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
RegionImpl - Class in org.jboss.cache
Default implementation of a Region
RegionImpl(Fqn, RegionManager) - Constructor for class org.jboss.cache.RegionImpl
Constructs a marshalling region from an fqn and region manager.
RegionImpl(EvictionPolicy, EvictionRegionConfig, Fqn, RegionManager) - Constructor for class org.jboss.cache.RegionImpl
Constructs an eviction region from a policy and configuration, defined by an fqn and region manager.
regionManager - Variable in class org.jboss.cache.interceptors.EvictionInterceptor
 
regionManager - Variable in class org.jboss.cache.loader.AbstractCacheLoader
 
regionManager - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
RegionManager - Class in org.jboss.cache
Manages multiple Regions for a Cache instance.
RegionManager() - Constructor for class org.jboss.cache.RegionManager
 
regionManager_ - Variable in class org.jboss.cache.eviction.LRUPolicy
 
RegionNameConflictException - Exception in org.jboss.cache.eviction
MarshRegion name conflicts with pre-existing regions.
RegionNameConflictException() - Constructor for exception org.jboss.cache.eviction.RegionNameConflictException
 
RegionNameConflictException(String) - Constructor for exception org.jboss.cache.eviction.RegionNameConflictException
 
RegionNameConflictException(String, Throwable) - Constructor for exception org.jboss.cache.eviction.RegionNameConflictException
 
RegionNameConflictException - Exception in org.jboss.cache.marshall
MarshRegion name conflicts with pre-existing regions.
RegionNameConflictException() - Constructor for exception org.jboss.cache.marshall.RegionNameConflictException
 
RegionNameConflictException(String) - Constructor for exception org.jboss.cache.marshall.RegionNameConflictException
 
RegionNameConflictException(String, Throwable) - Constructor for exception org.jboss.cache.marshall.RegionNameConflictException
 
RegionNotEmptyException - Exception in org.jboss.cache
Thrown when an attempt is made to RegionManager.activate(Fqn) activate a subtree} root in Fqn that already has an existing node in the cache.
RegionNotEmptyException() - Constructor for exception org.jboss.cache.RegionNotEmptyException
 
RegionNotEmptyException(String) - Constructor for exception org.jboss.cache.RegionNotEmptyException
 
RegionNotEmptyException(String, Throwable) - Constructor for exception org.jboss.cache.RegionNotEmptyException
 
RegionNotFoundException - Exception in org.jboss.cache.marshall
MarshRegion name not found.
RegionNotFoundException() - Constructor for exception org.jboss.cache.marshall.RegionNotFoundException
 
RegionNotFoundException(String) - Constructor for exception org.jboss.cache.marshall.RegionNotFoundException
 
RegionNotFoundException(String, Throwable) - Constructor for exception org.jboss.cache.marshall.RegionNotFoundException
 
registerAtHead(Synchronization) - Method in class org.jboss.cache.interceptors.OrderedSynchronizationHandler
 
registerAtTail(Synchronization) - Method in class org.jboss.cache.interceptors.OrderedSynchronizationHandler
 
registerCache(Cache<Object, Object>, String) - Method in class org.jboss.cache.CacheManagerImpl
 
registerCacheMBean(MBeanServer, CacheJmxWrapperMBean, String) - Static method in class org.jboss.cache.jmx.JmxUtil
 
registerComponent(Object, Class) - Method in class org.jboss.cache.factories.ComponentRegistry
Adds a singleton instance to the registry.
registerComponent(String, Object, Class) - Method in class org.jboss.cache.factories.ComponentRegistry
Adds an instance component to the registry, registering the component under the given name.
registerConfiguration(String, Configuration) - Method in interface org.jboss.cache.config.ConfigurationRegistry
Register the given configuration under the given name.
registerConfiguration(String, Configuration) - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
registerContextClassLoader(ClassLoader) - Method in interface org.jboss.cache.Region
Registers a specific ClassLoader for this region, overridding the default cache class loader.
registerContextClassLoader(ClassLoader) - Method in class org.jboss.cache.RegionImpl
 
registerDefaultClassLoader(ClassLoader) - Method in class org.jboss.cache.factories.ComponentRegistry
Registers the default class loader.
REGISTERED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The MBean has been instantiated and has completed MBeanRegistration.postRegister
registerInterceptors() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
registerInterceptors(MBeanServer, List<Interceptor>, String) - Static method in class org.jboss.cache.jmx.JmxUtil
 
registerSynchronization(Synchronization) - Method in class org.jboss.cache.transaction.DummyTransaction
Register a Synchronization callback with this transaction.
release(Object) - Method in class org.jboss.cache.lock.IdentityLock
Release the lock held by the owner.
release(Object) - Method in interface org.jboss.cache.lock.NodeLock
Releases the lock held by the owner.
releaseAll() - Method in class org.jboss.cache.lock.IdentityLock
Release all locks associated with this instance.
releaseAll(Object) - Method in class org.jboss.cache.lock.IdentityLock
 
releaseAll() - Method in interface org.jboss.cache.lock.NodeLock
Releases all locks associated with this instance.
releaseAll(Object) - Method in interface org.jboss.cache.lock.NodeLock
Releases all locks with this owner.
releaseAllLocks(List<Fqn>) - Method in class org.jboss.cache.lock.StripedLock
Releases locks on all fqns passed in.
releaseAllLocksFIFO(Object) - Method in class org.jboss.cache.transaction.TransactionEntry
Releases all locks held by the owner, in order of creation.
releaseAllLocksLIFO(Object) - Method in class org.jboss.cache.transaction.TransactionEntry
Releases all locks held by the owner, in reverse order of creation.
releaseAllLocksMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
releaseAllLocksMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
releaseCache(String) - Method in interface org.jboss.cache.CacheManager
Notifies the registry that the caller is no longer using the given cache.
releaseCache(String) - Method in class org.jboss.cache.CacheManagerImpl
 
releaseForce() - Method in class org.jboss.cache.lock.IdentityLock
Same as releaseAll now.
releaseLock(Fqn) - Method in class org.jboss.cache.lock.StripedLock
Releases a lock the caller may be holding.
releaseObjectReferences(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
releaseObjectReferences(boolean) - Method in interface org.jboss.cache.Node
Method that releases object references of cached objects held in the cache by serializing them to byte buffers.
releaseObjectReferences(boolean) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
releaseObjectReferences(boolean) - Method in class org.jboss.cache.UnversionedNode
 
releaseReaderOwners(LockStrategy) - Method in class org.jboss.cache.lock.LockMap
 
releaseStateTransferLocks(NodeSPI, Object, boolean) - Method in class org.jboss.cache.statetransfer.StateTransferManager
Releases all state transfer locks acquired.
remoteAnnounceBuddyPoolNameMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
remoteAnnounceBuddyPoolNameMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
remoteAssignToBuddyGroupMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
remoteAssignToBuddyGroupMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
RemoteCacheInvocationDelegate - Class in org.jboss.cache.invocation
A sublcass of CacheInvocationDelegate, used by remote instances to invoke methods on current cache.
RemoteCacheInvocationDelegate() - Constructor for class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
remoteRemoveFromBuddyGroupMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
remoteRemoveFromBuddyGroupMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
remove(Fqn<?>, K) - Method in interface org.jboss.cache.Cache
Removes the mapping for this key from a Node.
remove(String, K) - Method in interface org.jboss.cache.Cache
Convenience method that takes a string representation of an Fqn.
remove(Fqn<?>, K) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
remove(String, K) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
remove(K) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
remove(Fqn, Object) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
remove(Fqn, Object) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Removes attribute's value for a key.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Deletes the node for a given FQN and all its descendent nodes.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Deletes a single FQN-key-value record.
remove(Fqn, Object) - Method in interface org.jboss.cache.loader.CacheLoader
Removes the given key and value from the attributes of the given node.
remove(Fqn) - Method in interface org.jboss.cache.loader.CacheLoader
Removes the given node and all its subnodes, does nothing if the node does not exist.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Removes the given key and value from the attributes of the given node.
remove(Fqn) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Removes the given node.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Fetches the remove value, does not remove.
remove(Fqn) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing; replication handles removal.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.FileCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.JDBCCacheLoader
As per interface's contrect.
remove(Fqn) - Method in class org.jboss.cache.loader.JDBCCacheLoaderOld
Deprecated. Removes a node and all its children.
remove(Fqn) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Deletes the node for a given FQN and all its descendent nodes.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Deletes a single FQN-key-value record.
remove(Fqn, Object) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
remove(Fqn, Object) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
remove(Fqn, Object) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
remove(Fqn) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
REMOVE - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
remove(Fqn, Object) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
remove(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
remove(Object) - Method in class org.jboss.cache.lock.ThreadLocalMap
 
remove(Object) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
remove(K) - Method in interface org.jboss.cache.Node
Removes the mapping for this key from this node if it is present.
remove(K) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
remove(GlobalTransaction) - Method in class org.jboss.cache.transaction.TransactionTable
Removes a global transation, returns the old transaction entry.
remove(Transaction) - Method in class org.jboss.cache.transaction.TransactionTable
Removes a local transation, returns the global transaction entry.
remove(Object) - Method in class org.jboss.cache.UnversionedNode
 
remove(int) - Method in class org.jboss.cache.util.BitEncodedIntegerSet
Removes an integer from the set
remove(Object) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
remove(Object) - Method in class org.jboss.cache.util.DeltaMap
 
remove(Map<K, V>, K) - Static method in class org.jboss.cache.util.MinMapUtil
Removes a mapping by key from a map, returns the map.
REMOVE_DATA - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
REMOVE_KEY - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
removeAll() - Method in class org.jboss.cache.lock.LockMap
Remove all ownership.
removeAll(Collection<?>) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
removeAllCacheListeners() - Method in class org.jboss.cache.notifications.Notifier
Removes all listeners from the notifier, including the evictionPolicyListener.
removeBuddies(Collection<Address>) - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
removeCacheListener(Object) - Method in interface org.jboss.cache.Cache
Removes a CacheListener-annotated object from the cache.
removeCacheListener(Fqn<?>, Object) - Method in interface org.jboss.cache.Cache
Removes a CacheListener-annotated object from a given region.
removeCacheListener(Object) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeCacheListener(Fqn, Object) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeCacheListener(Object) - Method in class org.jboss.cache.notifications.Notifier
Removes a cache listener from the list of cache listeners registered.
removeChild(Fqn<?>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
removeChild(Object) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
removeChild(Fqn<?>) - Method in interface org.jboss.cache.Node
Removes a child node specified by the given relative Fqn.
removeChild(Object) - Method in interface org.jboss.cache.Node
Removes a child node specified by the given name.
removeChild(Fqn) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
removeChild(Object) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
removeChildConfig(ConfigurationComponent) - Method in class org.jboss.cache.config.ConfigurationComponent
 
removeChildConfigs(Collection<? extends ConfigurationComponent>) - Method in class org.jboss.cache.config.ConfigurationComponent
 
removeChildDirect(Fqn) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
removeChildDirect(Object) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
removeChildDirect(Fqn) - Method in interface org.jboss.cache.NodeSPI
Removes a child directly from a node.
removeChildDirect(Object) - Method in interface org.jboss.cache.NodeSPI
Removes a child directly from a node.
removeChildDirect(Object) - Method in class org.jboss.cache.UnversionedNode
 
removeChildDirect(Fqn) - Method in class org.jboss.cache.UnversionedNode
 
removeChildrenDirect() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
removeChildrenDirect() - Method in interface org.jboss.cache.NodeSPI
Directly removes all children for this node.
removeChildrenDirect() - Method in class org.jboss.cache.UnversionedNode
 
removeData(Fqn) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
removeData(Fqn) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Nullifies the node.
removeData(Fqn) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
removeData(Fqn) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Clears the map for the given node, but does not remove the node.
removeData(Fqn) - Method in interface org.jboss.cache.loader.CacheLoader
Removes all attributes from a given node, but doesn't delete the node itself or any subnodes.
removeData(Fqn) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Removes all attributes from a given node, but doesn't delete the node itself
removeData(Fqn) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing; replication handles removal.
removeData(Fqn) - Method in class org.jboss.cache.loader.FileCacheLoader
 
removeData(Fqn) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Clears the map for the given node, but does not remove the node.
removeData(Fqn) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
removeData(Fqn) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
removeData(Fqn) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
removeData(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
removeDataMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeDataMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeDataVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeDataVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removedEntries - Variable in class org.jboss.cache.util.Util.MapModifications
 
removeDirect(K) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
removeDirect(K) - Method in interface org.jboss.cache.NodeSPI
Removes a data key directly from a node.
removeDirect(Object) - Method in class org.jboss.cache.UnversionedNode
 
removeFromBuddyGroup(String) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
removeFromEnvironment(String) - Method in class org.jboss.cache.transaction.DummyContext
Removes an environment property from the environment of this context.
removeInterceptor(int) - Method in class org.jboss.cache.CacheImpl
 
removeInterceptor(Class<? extends Interceptor>) - Method in class org.jboss.cache.CacheImpl
 
removeInterceptor(int) - Method in interface org.jboss.cache.CacheSPI
Removes the interceptor at a specified position, where the first interceptor in the chain is at position 0 and the last one at getInterceptorChain().size() - 1.
removeInterceptor(Class<? extends Interceptor>) - Method in interface org.jboss.cache.CacheSPI
Removes the interceptor of specified type.
removeInterceptor(int) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeInterceptor(Class<? extends Interceptor>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeKeyMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeKeyMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeKeyVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeKeyVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeNode(Fqn<?>) - Method in interface org.jboss.cache.Cache
Removes a Node indicated by absolute Fqn.
removeNode(String) - Method in interface org.jboss.cache.Cache
Convenience method that takes a string representation of an Fqn.
removeNode(Fqn<?>) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeNode(String) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeNode(Fqn) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
Is thread safe so you dont need to deal with synchronising access to this method.
removeNode(Fqn) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
removeNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
removeNodeEntry(NodeEntry) - Method in interface org.jboss.cache.eviction.EvictionQueue
Remove a NodeEntry from queue.
removeNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.FIFOQueue
 
removeNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.LFUQueue
 
removeNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.LRUQueue
 
removeNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.MRUQueue
 
removeNodeEntry(NodeEntry) - Method in class org.jboss.cache.eviction.NullEvictionQueue
No-op
removeNodeMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeNodeMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeNodeVersionedMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeNodeVersionedMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
removeNotificationListener(NotificationListener) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
removeObject(Fqn) - Method in interface org.jboss.cache.loader.CacheLoaderAop
Removes the object with the given key from the persistent store.
removeReader(Object) - Method in class org.jboss.cache.lock.LockMap
Remove reader ownership.
removeRegion(Fqn<?>) - Method in interface org.jboss.cache.Cache
Removes a region denoted by the Fqn passed in.
removeRegion(Fqn<?>) - Method in class org.jboss.cache.CacheImpl
 
removeRegion(Fqn) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
removeRegion(Fqn) - Method in class org.jboss.cache.RegionManager
Removes a Region identified by the given fqn.
removeRegionToProcess(Region) - Method in class org.jboss.cache.eviction.EvictionTimerTask
Remove a MarshRegion to process from the Eviction thread.
removeWriter() - Method in class org.jboss.cache.lock.LockMap
Remove writer ownership.
rename(Name, Name) - Method in class org.jboss.cache.transaction.DummyContext
Binds a new name to the object bound to an old name, and unbinds the old name.
rename(String, String) - Method in class org.jboss.cache.transaction.DummyContext
Binds a new name to the object bound to an old name, and unbinds the old name.
replace(K, V) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
replace(K, V, V) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
replace(K, V) - Method in interface org.jboss.cache.Node
Replace entry for key only if currently mapped to some value.
replace(K, V, V) - Method in interface org.jboss.cache.Node
Replace entry for key only if currently mapped to given value.
replace(K, V) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
replace(K, V, V) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
replaceAll(Map<K, V>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
replaceAll(Map<K, V>) - Method in interface org.jboss.cache.Node
Similar to Node.putAll(java.util.Map) except that it removes any entries that exists in the data map first.
replaceAll(Map<K, V>) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
replaceChildConfig(ConfigurationComponent, ConfigurationComponent) - Method in class org.jboss.cache.config.ConfigurationComponent
 
replaceChildConfigs(Collection<? extends ConfigurationComponent>, Collection<? extends ConfigurationComponent>) - Method in class org.jboss.cache.config.ConfigurationComponent
 
replicateAllMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
replicateAllMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
replicateCall(InvocationContext, MethodCall, boolean, Option, boolean) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
replicateCall(InvocationContext, MethodCall, boolean, Option) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
replicateCall(InvocationContext, List<Address>, MethodCall, boolean, Option) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
replicateCall(InvocationContext, List<Address>, MethodCall, boolean, Option, boolean, boolean) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
replicateMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
replicateMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
ReplicationException - Exception in org.jboss.cache
Thrown when a replication problem occurred
ReplicationException() - Constructor for exception org.jboss.cache.ReplicationException
 
ReplicationException(Throwable) - Constructor for exception org.jboss.cache.ReplicationException
 
ReplicationException(String) - Constructor for exception org.jboss.cache.ReplicationException
 
ReplicationException(String, Throwable) - Constructor for exception org.jboss.cache.ReplicationException
 
ReplicationInterceptor - Class in org.jboss.cache.interceptors
Takes care of replicating modifications to other nodes in a cluster.
ReplicationInterceptor() - Constructor for class org.jboss.cache.interceptors.ReplicationInterceptor
 
ReplicationQueue - Class in org.jboss.cache.cluster
Periodically (or when certain size is exceeded) takes elements and replicates them.
ReplicationQueue() - Constructor for class org.jboss.cache.cluster.ReplicationQueue
 
ReplicationQueueFactory - Class in org.jboss.cache.factories
RPCManager factory
ReplicationQueueFactory() - Constructor for class org.jboss.cache.factories.ReplicationQueueFactory
 
reportAndRethrowError(String, Exception) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
reset() - Method in interface org.jboss.cache.config.EvictionPolicyConfig
Resets the values to their defaults.
reset() - Method in class org.jboss.cache.config.Option
Resets this option to defaults.
reset() - Method in class org.jboss.cache.config.RuntimeConfig
Resets the runtime to default values.
reset() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
reset() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
reset() - Method in class org.jboss.cache.eviction.FIFOConfiguration
 
reset() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
reset() - Method in class org.jboss.cache.eviction.MRUConfiguration
 
reset() - Method in class org.jboss.cache.eviction.NullEvictionPolicyConfig
No-op
reset() - Method in class org.jboss.cache.factories.ComponentRegistry
Wipes everything in the registry.
reset() - Method in class org.jboss.cache.InvocationContext
Resets this to the defaults used when constructing an invocation context object
reset() - Method in class org.jboss.cache.marshall.io.ReusableObjectInputStream
Resets the ObjectInputStream so it can be reused, by resetting and clearing any internal caches and by clearing the underlying byte stream to free up memory.
reset() - Method in class org.jboss.cache.marshall.io.ReusableObjectOutputStream
Unlike ObjectOutputStream.reset(), this method will flush and wipe the underlying byte stream, and ensure ObjectOutputStream headers are rewritten, awaiting proper reuse.
reset() - Method in class org.jboss.cache.RegionManager
Resets the region manager's regions registry
reset() - Method in class org.jboss.cache.transaction.TransactionEntry
Cleans up internal state
resetEvictionQueue(Region) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
 
resetEvictionQueue(Region) - Method in interface org.jboss.cache.eviction.EvictionAlgorithm
Reset the whole eviction queue.
resetEvictionQueue(Region) - Method in class org.jboss.cache.eviction.ExpirationAlgorithm
 
resetEvictionQueue(Region) - Method in class org.jboss.cache.eviction.NullEvictionAlgorithm
No-op
resetEvictionQueues() - Method in interface org.jboss.cache.Region
Clears the node event queue used for processing eviction.
resetEvictionQueues() - Method in class org.jboss.cache.RegionImpl
 
resetStatistics() - Method in class org.jboss.cache.interceptors.ActivationInterceptor
 
resetStatistics() - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
resetStatistics() - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
resetStatistics() - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
resetStatistics() - Method in class org.jboss.cache.interceptors.Interceptor
This implementation is a no-op.
resetStatistics() - Method in interface org.jboss.cache.interceptors.InterceptorMBean
Resets an interceptor's cache statistics
resetStatistics() - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
resetStatistics() - Method in class org.jboss.cache.interceptors.PassivationInterceptor
 
resetStatistics() - Method in class org.jboss.cache.interceptors.TxInterceptor
 
resident - Variable in class org.jboss.cache.AbstractNode
 
resortEvictionQueue(boolean) - Method in class org.jboss.cache.eviction.BaseSortedEvictionAlgorithm
This method is called to resort the queue after add or visit events have occurred.
resortEvictionQueue() - Method in class org.jboss.cache.eviction.ElementSizeQueue
 
resortEvictionQueue() - Method in class org.jboss.cache.eviction.LFUQueue
 
resortEvictionQueue() - Method in interface org.jboss.cache.eviction.SortedEvictionQueue
Provide contract to resort a sorted queue.
restart() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
resume(Transaction) - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Resume the association of the calling thread with the given transaction.
retainAll(Collection<?>) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
returnStreamToPool(ReusableObjectOutputStream) - Method in class org.jboss.cache.marshall.io.ObjectStreamPool
 
returnStreamToPool(ObjectInputStream) - Method in class org.jboss.cache.marshall.io.ObjectStreamPool
 
returnValueForRemoteCall(int) - Static method in class org.jboss.cache.marshall.MethodDeclarations
Tests whether remote calls to this method should return the value to the caller or just return a null (more efficient if the caller won't use this value anyway)
ReusableObjectInputStream - Class in org.jboss.cache.marshall.io
A reusable ObjectInputStream that uses an internal byte array.
ReusableObjectInputStream() - Constructor for class org.jboss.cache.marshall.io.ReusableObjectInputStream
 
ReusableObjectInputStream(ReusableObjectInputStream.ResettableByteArrayInputStream) - Constructor for class org.jboss.cache.marshall.io.ReusableObjectInputStream
 
ReusableObjectOutputStream - Class in org.jboss.cache.marshall.io
An ObjectOutputStream that can safely be reset and reused.
ReusableObjectOutputStream() - Constructor for class org.jboss.cache.marshall.io.ReusableObjectOutputStream
 
ReusableObjectOutputStream(ReusableObjectOutputStream.ResettableByteArrayOutputStream) - Constructor for class org.jboss.cache.marshall.io.ReusableObjectOutputStream
 
rollback(GlobalTransaction) - Method in class org.jboss.cache.CacheImpl
Throws UnsupportedOperationException.
rollback(Object) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
rollback(Object) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
rollback(Object) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Rolls back a transaction.
rollback(Object) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Commits the given transaction, or throws IllegalArgumentException if the given key is not associated with an uncommited transaction.
rollback(Object) - Method in interface org.jboss.cache.loader.CacheLoader
Rolls the transaction back.
rollback(Object) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Roll the transaction back.
rollback(Object) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Does nothing.
rollback(Object) - Method in interface org.jboss.cache.loader.ConnectionFactory
 
rollback(Object) - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
rollback(Object) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
rollback(Object) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
rollback() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Rolls back the transaction associated with the calling thread.
rollback() - Method in class org.jboss.cache.transaction.DummyTransaction
Rolls back this transaction.
rollback() - Method in class org.jboss.cache.transaction.DummyUserTransaction
Rolls back this transaction.
rollbackMethod - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
rollbackMethod_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
ROOT - Static variable in class org.jboss.cache.Fqn
Immutable root FQN.
root() - Static method in class org.jboss.cache.Fqn
 
ROOT - Static variable in class org.jboss.cache.xml.XmlHelper
The root of a JBoss Cache configuration XML file.
rpcManager - Variable in class org.jboss.cache.RegionManager
 
RPCManager - Interface in org.jboss.cache
Provides a mechanism for communicating with other caches in the cluster.
RPCManagerImpl - Class in org.jboss.cache
Manager that handles all RPC calls between JBoss Cache instances
RPCManagerImpl() - Constructor for class org.jboss.cache.RPCManagerImpl
 
RPCManagerImpl.MembershipListenerAdaptor - Class in org.jboss.cache
 
RPCManagerImpl.MembershipListenerAdaptor() - Constructor for class org.jboss.cache.RPCManagerImpl.MembershipListenerAdaptor
 
runCommitPhase(InvocationContext, GlobalTransaction, Transaction, List, List, boolean) - Method in class org.jboss.cache.interceptors.TxInterceptor
creates a commit() MethodCall and feeds it to handleCommitRollback();
runPreparePhase(MethodCall, GlobalTransaction, InvocationContext) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
Calls prepare(GlobalTransaction,List,org.jgroups.Address,boolean)) in all members except self.
runPreparePhase(InvocationContext, GlobalTransaction, List) - Method in class org.jboss.cache.interceptors.TxInterceptor
Handles a local prepare - invoked by the sync handler.
runRollbackPhase(InvocationContext, GlobalTransaction, Transaction, List) - Method in class org.jboss.cache.interceptors.TxInterceptor
creates a rollback() MethodCall and feeds it to handleCommitRollback();
RuntimeConfig - Class in org.jboss.cache.config
 
RuntimeConfig() - Constructor for class org.jboss.cache.config.RuntimeConfig
 
RuntimeConfigAwareFactory - Class in org.jboss.cache.factories
An extension of the EmptyConstructorFactory that places a component in the RuntimeConfig after creating it.
RuntimeConfigAwareFactory() - Constructor for class org.jboss.cache.factories.RuntimeConfigAwareFactory
 

S

safeClose(InputStream) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
safeClose(Statement) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
safeClose(ResultSet) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
safeEquals(Object, Object) - Static method in class org.jboss.cache.config.ConfigurationComponent
Null-safe equality test.
SemaphoreLock - Class in org.jboss.cache.lock
Implements most of the methods of Lock using the Semaphore implementation.
SemaphoreLock(int) - Constructor for class org.jboss.cache.lock.SemaphoreLock
 
sendNotification(Notification) - Method in interface org.jboss.cache.jmx.CacheNotificationBroadcaster
Sends a notification to any interested NotificationListener.
SEPARATOR - Static variable in class org.jboss.cache.Fqn
Separator between FQN elements.
serialize() - Method in class org.jboss.cache.marshall.MarshalledValue
 
SERVICE_KEY_NAME - Static variable in class org.jboss.cache.jmx.JmxUtil
 
setActive(boolean) - Method in interface org.jboss.cache.Region
Sets this region as active - this only marks a flag and does not actually activates or deactivates this region.
setActive(boolean) - Method in class org.jboss.cache.RegionImpl
 
setAddress(Address) - Method in class org.jboss.cache.transaction.GlobalTransaction
 
setAsync(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setAutoDataGravitation(boolean) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setBatchSize(int) - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
setBindAddress(String) - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
setBindAddress(String) - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
setBuddyCommunicationTimeout(int) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setBuddyGroup(BuddyGroup) - Method in class org.jboss.cache.config.RuntimeConfig
 
setBuddyGroup(BuddyGroup) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setBuddyLocatorClass(String) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
setBuddyLocatorClass(String) - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
setBuddyLocatorConfig(BuddyReplicationConfig.BuddyLocatorConfig) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setBuddyLocatorProperties(Properties) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
setBuddyLocatorProperties(Properties) - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
setBuddyPoolName(String) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setBuddyReplicationConfig(BuddyReplicationConfig) - Method in class org.jboss.cache.config.Configuration
 
setBuddyReplicationConfig(Element) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setBuddyReplicationConfig(Element) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets the buddy replication configuration element
setCache(CacheSPI) - Method in class org.jboss.cache.config.ConfigurationComponent
Sets a back-reference to the cache associated with this configuration
setCache(CacheSPI) - Method in class org.jboss.cache.eviction.BaseEvictionPolicy
 
setCache(CacheSPI) - Method in interface org.jboss.cache.eviction.EvictionPolicy
Method called to set the cache in this implementation.
setCache(CacheSPI) - Method in class org.jboss.cache.eviction.LRUPolicy
 
setCache(CacheSPI) - Method in class org.jboss.cache.eviction.NullEvictionPolicy
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.Interceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.OptimisticLockingInterceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.OptimisticNodeInterceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.OptimisticValidatorInterceptor
 
setCache(CacheSPI) - Method in class org.jboss.cache.interceptors.PassivationInterceptor
 
setCache(Cache<K, V>) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Allows direct injection of the underlying cache.
setCache(CacheSPI) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
setCache(CacheSPI) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
setCache(CacheSPI) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Sets the CacheImpl owner of this cache loader.
setCache(CacheSPI) - Method in interface org.jboss.cache.loader.CacheLoader
Sets the CacheSPI that is maintaining this CacheLoader.
setCache(CacheSPI) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Sets the CacheImpl owner of this cache loader.
setCache(CacheSPI) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Sets the cache loader's CacheSPI reference and also adds a listener to the cache that reacts to cluster topology changes.
setCache(CacheSPI) - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
setCache(Cache) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setCache(Cache) - Method in interface org.jboss.cache.TreeCacheViewMBean
 
setCacheInLoader(CacheSPI, CacheLoader) - Method in class org.jboss.cache.loader.CacheLoaderManager
Sets the cache instance associated with the given cache loader.
setCacheJmxWrapper(CacheJmxWrapperMBean) - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
setCacheJmxWrapper(CacheJmxWrapperMBean) - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
Allows injection of the CacheSPI via a CacheJmxWrapperMBean.
setCacheLoader(CacheLoader) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
Provides the ability to get and set a running cache loader, which, if exists, will be used rather than constructing a new one.
setCacheLoader(CacheLoader) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
setCacheLoaderConfig(CacheLoaderConfig) - Method in class org.jboss.cache.config.Configuration
 
setCacheLoaderConfig(Element) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setCacheLoaderConfig(Element) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setCacheLoaderConfiguration(Element) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setCacheLoaderConfiguration(Element) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Deprecated. use LegacyConfiguration.setCacheLoaderConfig(org.w3c.dom.Element)
setCacheLoaderHasMods(boolean) - Method in class org.jboss.cache.InvocationContext
 
setCacheMarshaller(Marshaller) - Method in class org.jboss.cache.config.Configuration
 
setCacheMode(Configuration.CacheMode) - Method in class org.jboss.cache.config.Configuration
 
setCacheMode(String) - Method in class org.jboss.cache.config.Configuration
 
setCacheMode(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setCacheMode(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets the default caching mode)
setCacheModeLocal(boolean) - Method in class org.jboss.cache.config.Option
overriding CacheMode from REPL_SYNC, REPL_ASYNC, INVALIDATION_SYNC, INVALIDATION_ASYNC to LOCAL.
setCacheModeString(String) - Method in class org.jboss.cache.config.Configuration
 
setCacheObjectName(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setCacheService(CacheJmxWrapperMBean) - Method in interface org.jboss.cache.TreeCacheViewMBean
 
setChannel(Channel) - Method in class org.jboss.cache.config.RuntimeConfig
Sets the channel the cache will use.
setChannelFactory(ChannelFactory) - Method in class org.jboss.cache.CacheManagerImpl
 
setCheckCharacterPortability(boolean) - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
setChildrenLoaded(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setChildrenLoaded(boolean) - Method in interface org.jboss.cache.NodeSPI
Sets if the children of this node were loaded from a cache loader.
setChildrenLoaded(boolean) - Method in class org.jboss.cache.UnversionedNode
 
setChildrenMapDirect(Map<Object, Node<K, V>>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setChildrenMapDirect(Map<Object, Node<K, V>>) - Method in interface org.jboss.cache.NodeSPI
Sets the node's children explictly.
setChildrenMapDirect(Map<Object, Node<K, V>>) - Method in class org.jboss.cache.UnversionedNode
 
setClassName(String) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setClusterConfig(Element) - Method in class org.jboss.cache.config.Configuration
Converts a list of elements to a Java Groups property string.
setClusterConfig(String) - Method in class org.jboss.cache.config.Configuration
 
setClusterConfig(Element) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setClusterConfig(Element) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Convert a list of elements to the JG property string
setClusterName(String) - Method in class org.jboss.cache.config.Configuration
 
setClusterName(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setClusterName(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Set the name of the replication group
setClusterProperties(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setClusterProperties(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Set the cluster properties.
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Sets the configuration string for this cache loader.
setConfig(AdjListJDBCCacheLoaderConfig) - Method in class org.jboss.cache.loader.C3p0ConnectionFactory
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in interface org.jboss.cache.loader.CacheLoader
Sets the configuration.
setConfig(CacheLoaderConfig, CacheSPI, Configuration) - Method in class org.jboss.cache.loader.CacheLoaderManager
Sets a configuration object and creates a cacheloader accordingly.
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.ChainingCacheLoader
Sets the configuration.
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
Sets the configuration.
setConfig(AdjListJDBCCacheLoaderConfig) - Method in interface org.jboss.cache.loader.ConnectionFactory
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.FileCacheLoader
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Sets the configuration string for this cache loader.
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
setConfig(AdjListJDBCCacheLoaderConfig) - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Sets the config for SingletonStoreCacheLoader and for the delegating cache loader.
setConfig(String) - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
setConfig(String) - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
setConfig(CacheLoaderConfig.IndividualCacheLoaderConfig) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
Allows configuration via XML config file.
setConfiguration(Configuration) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Sets the configuration that the underlying cache should use.
setConfigurationRegistry(ConfigurationRegistry) - Method in class org.jboss.cache.CacheManagerImpl
 
setConnectionFactoryClass(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setContextClassLoaderAsCurrent(Fqn) - Method in class org.jboss.cache.RegionManager
Helper utility that checks for a ClassLoader registered for the given Fqn, and if found sets it as the TCCL.
setCreateTable(boolean) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setCreateTableDDL(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setCreationTimeStamp(long) - Method in class org.jboss.cache.eviction.NodeEntry
 
setCurrentlyInUse(boolean, long) - Method in class org.jboss.cache.eviction.NodeEntry
 
setData(Map) - Method in class org.jboss.cache.Modification
Sets the modification Map set.
setData(Map) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setDataGravitationRemoveOnFind(boolean) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setDataGravitationSearchBackupTrees(boolean) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setDataLoaded(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setDataLoaded(boolean) - Method in interface org.jboss.cache.NodeSPI
Sets if the data was loaded from the cache loader.
setDataLoaded(boolean) - Method in class org.jboss.cache.UnversionedNode
Sets if the data was loaded from the cache loader.
setDataOwner(Address) - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
setDatasourceName(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setDataVersion(DataVersion) - Method in class org.jboss.cache.config.Option
Passing in an DataVersion instance when using optimistic locking will override the default behaviour of internally generated version info and allow the caller to handle data versioning.
setDefaultClassLoader(ClassLoader) - Method in class org.jboss.cache.DefaultCacheFactory
Allows users to specify a default class loader to use for both the construction and running of the cache.
setDefaultEventQueueSize(int) - Method in class org.jboss.cache.config.EvictionConfig
 
setDefaultEventQueueSize(int) - Method in class org.jboss.cache.config.EvictionRegionConfig
 
setDefaultEvictionPolicyClass(String) - Method in class org.jboss.cache.config.EvictionConfig
 
setDefaultInactive(boolean) - Method in class org.jboss.cache.RegionManager
Sets if replication for new Regions is by default inactive.
setDelegate(Cache) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
setDelegate(NodeSPI) - Method in class org.jboss.cache.UnversionedNode
 
setDelegateCache(CacheSPI) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
setDeleteAllSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setDeleteNodeSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setDisableStateChangeNotifications(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Hook to allow PojoCacheJmxWrapper to suppress state change notifications from this mbean in lieu of its own.
setDriverClass(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setDropTable(boolean) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setDropTableDDL(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setElementDifference(int) - Method in class org.jboss.cache.eviction.EvictedEventNode
 
setEnabled(boolean) - Method in class org.jboss.cache.config.BuddyReplicationConfig
 
setEqualityPreferenceForInstance(boolean) - Method in class org.jboss.cache.marshall.MarshalledValue
 
setEventQueueSize(int) - Method in class org.jboss.cache.config.EvictionRegionConfig
 
setEventType(NodeEventType) - Method in class org.jboss.cache.eviction.EvictedEventNode
 
setEvictionConfig(EvictionConfig) - Method in class org.jboss.cache.config.Configuration
 
setEvictionConfig(EvictionConfig) - Method in class org.jboss.cache.RegionManager
Sets the eviction configuration.
setEvictionPolicy(EvictionPolicyConfig) - Method in interface org.jboss.cache.Region
Configures an eviction policy for this region.
setEvictionPolicy(EvictionPolicyConfig) - Method in class org.jboss.cache.RegionImpl
 
setEvictionPolicyClass(String) - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
This method should be overridden by subclass implementers to set the default policy class name for the subclass.
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.ExpirationConfiguration
 
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.FIFOConfiguration
 
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.LFUConfiguration
 
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
setEvictionPolicyClassName() - Method in class org.jboss.cache.eviction.MRUConfiguration
 
setEvictionPolicyConfig(EvictionPolicyConfig) - Method in class org.jboss.cache.config.EvictionRegionConfig
 
setEvictionPolicyConfig(Element) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setEvictionPolicyConfig(Element) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Setup eviction policy configuration
setEvictionRegionConfigs(List<EvictionRegionConfig>) - Method in class org.jboss.cache.config.EvictionConfig
 
setExpirationKeyName(String) - Method in class org.jboss.cache.eviction.ExpirationConfiguration
Sets the expirationKeyName.
setExposeManagementStatistics(boolean) - Method in class org.jboss.cache.config.Configuration
 
setExposeManagementStatistics(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setExposeManagementStatistics(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setFailSilently(boolean) - Method in class org.jboss.cache.config.Option
suppress any failures in your cache operation, including version mismatches with optimistic locking, timeouts obtaining locks, transaction rollbacks.
setFetchInMemoryState(boolean) - Method in class org.jboss.cache.config.Configuration
 
setFetchInMemoryState(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setFetchInMemoryState(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets whether or not any initial or subsequent partial state transfer should include in-memory state.
setFetchPersistentState(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setFirstInterceptor(Class<? extends Interceptor>) - Method in class org.jboss.cache.factories.InterceptorChainFactory
 
setFirstInterceptor(Interceptor) - Method in class org.jboss.cache.factories.InterceptorChainFactory
 
setForceAsynchronous(boolean) - Method in class org.jboss.cache.config.Option
Sets whether replication or invalidation should be done asynchronously, even if the cache is configured in a synchronous mode.
setForceAsyncReplication(boolean) - Method in class org.jboss.cache.transaction.TransactionEntry
Sets the value of the forceAsyncReplication flag.
setForceDataGravitation(boolean) - Method in class org.jboss.cache.config.Option
Enables data gravitation calls if a cache miss is detected when using setForceSynchronous(boolean) - Method in class org.jboss.cache.config.Option
Sets whether replication or invalidation should be done synchronously, even if the cache is configured in an asynchronous mode.
setForceSyncReplication(boolean) - Method in class org.jboss.cache.transaction.TransactionEntry
Sets the value of the forceSyncReplication flag.
setForceWriteLock(boolean) - Method in class org.jboss.cache.config.Option
Forces a write lock to be acquired on the call, regardless of whether it is a read or write.
setFqn(Fqn) - Method in class org.jboss.cache.eviction.EvictedEventNode
 
setFqn(Fqn<?>) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setFqn(Fqn) - Method in class org.jboss.cache.Modification
Sets the modification fqn.
setFqn(Fqn<?>) - Method in interface org.jboss.cache.NodeSPI
Sets the FQN of this node and resets the names of all children as well.
setFqn(Fqn) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setFqn(Fqn) - Method in class org.jboss.cache.UnversionedNode
 
setFqn2(Fqn) - Method in class org.jboss.cache.Modification
 
setGlobalTransaction(GlobalTransaction) - Method in class org.jboss.cache.InvocationContext
Sets the global transaction associated with this invocation
setGroupName(String) - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
setGroupRequestMode(int) - Method in class org.jboss.cache.config.Option
By default, the RPCManager has inbuilt logic when it comes to selecting a group request mode.
setHost(String) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
setId(long) - Method in class org.jboss.cache.transaction.GlobalTransaction
 
setIgnoreColocatedBuddies(boolean) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
setIgnoreModifications(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setInactiveOnStartup(boolean) - Method in class org.jboss.cache.config.Configuration
 
setInactiveOnStartup(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setInactiveOnStartup(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets whether the entire tree is inactive upon startup, only responding to replication messages after Region.activate() is called to activate one or more parts of the tree.
setIndividualCacheLoaderConfigs(List<CacheLoaderConfig.IndividualCacheLoaderConfig>) - Method in class org.jboss.cache.config.CacheLoaderConfig
 
setInitialStateRetrievalTimeout(long) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
Deprecated. 
setInitialStateRetrievalTimeout(long) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Deprecated. use LegacyConfiguration.setStateRetrievalTimeout(long)
setInsertNodeSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setInternalState(Map) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setInternalState(Map) - Method in interface org.jboss.cache.NodeSPI
Very similar to NodeSPI.putAllDirect(java.util.Map) except that this method first scans the map for any internal attributes using special _JBOSS_INTERNAL_XXX Strings as keys, and uses these to set internal attributes before passing the remaining attributes to NodeSPI.putAllDirect(java.util.Map).
setInternalState(Map) - Method in class org.jboss.cache.UnversionedNode
 
setInternalState(Map) - Method in class org.jboss.cache.VersionedNode
 
setInUseTimeout(long) - Method in class org.jboss.cache.eviction.EvictedEventNode
 
setInvocationContext(InvocationContext) - Method in interface org.jboss.cache.Cache
Sets the passed in InvocationContext as current.
setInvocationContext(InvocationContext) - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
setIsolationLevel(IsolationLevel) - Method in class org.jboss.cache.config.Configuration
 
setIsolationLevel(String) - Method in class org.jboss.cache.config.Configuration
 
setIsolationLevel(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setIsolationLevel(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Set the transaction isolation level.
setIsolationLevel(IsolationLevel) - Static method in class org.jboss.cache.lock.LockStrategyFactory
 
setIsolationLevelString(String) - Method in class org.jboss.cache.config.Configuration
 
setJdbcPassword(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setJdbcURL(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setJdbcUser(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setKey(Object) - Method in class org.jboss.cache.Modification
Sets the modification key.
setLast(Interceptor) - Method in class org.jboss.cache.interceptors.Interceptor
 
setLastInterceptorPointer(Interceptor, Interceptor) - Static method in class org.jboss.cache.factories.InterceptorChainFactory
 
setLocalRollbackOnly(boolean) - Method in class org.jboss.cache.InvocationContext
Wipe list of previously peeked nodes.
setLocation(String) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
setLocation(String) - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
setLocation(String) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
setLockAcquisitionTimeout(long) - Method in class org.jboss.cache.config.Configuration
 
setLockAcquisitionTimeout(int) - Method in class org.jboss.cache.config.Option
Sets any lock acquisition timeout configured for the call.
setLockAcquisitionTimeout(long) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setLockAcquisitionTimeout(long) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Set the max time for lock acquisition.
setLockForChildInsertRemove(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setLockForChildInsertRemove(boolean) - Method in interface org.jboss.cache.Node
Configures the behaviour of how this node is locked when adding/removing children.
setLockForChildInsertRemove(boolean) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
setLockForChildInsertRemove(boolean) - Method in class org.jboss.cache.UnversionedNode
 
setLockParentForChildInsertRemove(boolean) - Method in class org.jboss.cache.config.Configuration
Sets whether inserting or removing a node requires a write lock on the node's parent (when pessimistic locking is used.)
setMarshallerClass(String) - Method in class org.jboss.cache.config.Configuration
 
setMaxAgeSeconds(int) - Method in class org.jboss.cache.eviction.LRUConfiguration
 
setMaxElementsPerNode(int) - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
setMaxNodes(int) - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
setMethodCall(MethodCall) - Method in class org.jboss.cache.InvocationContext
Sets the method call associated with this invocation.
setMethodId(int) - Method in class org.jboss.cache.marshall.MethodCall
 
setMinNodes(int) - Method in class org.jboss.cache.eviction.LFUConfiguration
 
setMinTimeToLiveSeconds(int) - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
setModificationType(NodeModifiedEvent.ModificationType) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setModifiedTimeStamp(long) - Method in class org.jboss.cache.eviction.NodeEntry
 
setMultiplexerService(JChannelFactoryMBean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setMultiplexerService(JChannelFactoryMBean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setMultiplexerStack(String) - Method in class org.jboss.cache.config.Configuration
 
setMultiplexerStack(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setMultiplexerStack(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Used with JGroups multiplexer, specifies stack to be used (e.g., fc-fast-minimalthreads) This attribute is optional; if not provided, a default multiplexer stack will be used.
setMuxChannelFactory(ChannelFactory) - Method in class org.jboss.cache.config.RuntimeConfig
Sets the factory the cache should use to create a multiplexed channel.
setMuxChannelFactory(ChannelFactory) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setMuxChannelFactory(ChannelFactory) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setNewView(View) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setNext(Interceptor) - Method in class org.jboss.cache.interceptors.Interceptor
 
setNodeFactory(NodeFactory) - Method in class org.jboss.cache.config.RuntimeConfig
 
setNodeLockingOptimistic(boolean) - Method in class org.jboss.cache.config.Configuration
 
setNodeLockingScheme(Configuration.NodeLockingScheme) - Method in class org.jboss.cache.config.Configuration
 
setNodeLockingScheme(String) - Method in class org.jboss.cache.config.Configuration
 
setNodeLockingScheme(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setNodeLockingScheme(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setNodeLockingSchemeString(String) - Method in class org.jboss.cache.config.Configuration
 
setNodes(Map<Fqn, WorkspaceNode<K, V>>) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
 
setNodes(Map<Fqn, WorkspaceNode<K, V>>) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
Sets the nodes.
setNotificationServiceName(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setNumberOfElements(int) - Method in class org.jboss.cache.eviction.NodeEntry
 
setNumberOfNodeVisits(int) - Method in class org.jboss.cache.eviction.NodeEntry
 
setNumBuddies(int) - Method in class org.jboss.cache.buddyreplication.NextMemberBuddyLocatorConfig
 
setObjectInputStreamPoolSize(int) - Method in class org.jboss.cache.config.Configuration
Initialises the size of the object input stream pool size, which defaults to 50.
setObjectOutputStreamPoolSize(int) - Method in class org.jboss.cache.config.Configuration
Initialises the size of the object output stream pool size, which defaults to 50.
setOldValue(Object) - Method in class org.jboss.cache.Modification
Sets the post modification old value.
setOption(Option) - Method in class org.jboss.cache.transaction.TransactionEntry
Sets a transaction-scope option override
setOptionOverrides(Option) - Method in class org.jboss.cache.InvocationContext
Sets the option overrides associated with this invocation
setOrderedSynchronizationHandler(OrderedSynchronizationHandler) - Method in class org.jboss.cache.transaction.TransactionEntry
 
setOriginal(Map<K, V>) - Method in class org.jboss.cache.util.DeltaMap
Sets the original values of this delta map.
setOriginLocal(boolean) - Method in class org.jboss.cache.InvocationContext
If set to true, the invocation is assumed to have originated locally.
setOriginLocal(boolean) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setPassivation(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig
 
setPort(int) - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
setPort(int) - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
setPort(int) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
setPre(boolean) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setPreload(String) - Method in class org.jboss.cache.config.CacheLoaderConfig
 
setProperties(String) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.FileCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.JDBCCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoaderConfig
 
setProperties(Properties) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
setPurgeOnStartup(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setPushStateWhenCoordinator(boolean) - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
setPushStateWhenCoordinatorTimeout(int) - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
setQueueSize(int) - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
setReconnectWaitTime(int) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
setRegionFqn(Fqn) - Method in class org.jboss.cache.config.EvictionRegionConfig
 
setRegionManager(RegionManager) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
setRegionManager(RegionManager) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
setRegionManager(RegionManager) - Method in interface org.jboss.cache.loader.CacheLoader
Sets the RegionManager this object should use to manage marshalling/unmarshalling of different regions using different classloaders.
setRegionManager(RegionManager) - Method in class org.jboss.cache.loader.ChainingCacheLoader
No-op, as this class doesn't directly use the ERegionManager.
setRegionManager(RegionManager) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
setRegionName(String) - Method in class org.jboss.cache.config.EvictionRegionConfig
 
setRegisterInterceptors(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setRegisterInterceptors(boolean) - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
Sets whether this object should register the cache's interceptors with JMX during CacheJmxWrapperMBean.create().
setRemote(boolean) - Method in class org.jboss.cache.transaction.GlobalTransaction
 
setReplicationVersion(short) - Method in class org.jboss.cache.config.Configuration
 
setReplicationVersion(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setReplicationVersion(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets the format version of the data transferred during an initial state transfer or a call to Region.activate().
setReplQueueInterval(long) - Method in class org.jboss.cache.config.Configuration
 
setReplQueueInterval(long) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setReplQueueInterval(long) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setReplQueueMaxElements(int) - Method in class org.jboss.cache.config.Configuration
 
setReplQueueMaxElements(int) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setReplQueueMaxElements(int) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setReplVersionString(String) - Method in class org.jboss.cache.config.Configuration
 
setRequestMarshaller(RpcDispatcher.Marshaller) - Method in class org.jboss.cache.marshall.InactiveRegionAwareRpcDispatcher
 
setResetElementCount(boolean) - Method in class org.jboss.cache.eviction.EvictedEventNode
 
setResident(boolean) - Method in class org.jboss.cache.AbstractNode
 
setResident(boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setResident(boolean) - Method in interface org.jboss.cache.Node
 
setReturnOld(boolean) - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
setRollbackOnly() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Mark the transaction associated with the calling thread for rollback only.
setRollbackOnly() - Method in class org.jboss.cache.transaction.DummyTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRollbackOnly() - Method in class org.jboss.cache.transaction.DummyUserTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRPCManager(RPCManager) - Method in class org.jboss.cache.config.RuntimeConfig
 
setRuntimeConfig(RuntimeConfig) - Method in class org.jboss.cache.config.Configuration
 
setSelectChildFqnsSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setSelectChildNamesSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setSelectNodeSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setServiceName(String) - Method in class org.jboss.cache.jmx.CacheNotificationListener
 
setShared(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig
 
setShutdownHookBehavior(Configuration.ShutdownHookBehavior) - Method in class org.jboss.cache.config.Configuration
 
setShutdownHookBehavior(String) - Method in class org.jboss.cache.config.Configuration
 
setSingletonStoreClass(String) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
setSingletonStoreClass(String) - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
setSingletonStoreConfig(CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
setSingletonStoreEnabled(boolean) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
setSingletonStoreEnabled(boolean) - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
 
setSingletonStoreproperties(Properties) - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
setSingletonStoreproperties(Properties) - Method in class org.jboss.cache.loader.SingletonStoreDefaultConfig
Takes the properties defined and populates the individual instance fields of the default singleton store cache loader configuration.
setSkipCacheStatusCheck(boolean) - Method in class org.jboss.cache.config.Option
If set to true, cache lifecycle checks will be skipped.
setSkipDataGravitation(boolean) - Method in class org.jboss.cache.config.Option
Suppresses data gravitation when buddy replication is used.
setState(InvocationContext) - Method in class org.jboss.cache.InvocationContext
Sets the state of the InvocationContext based on the template context passed in
setState(byte[]) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
setState(InputStream) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
setState(String, byte[]) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
setState(String, InputStream) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
setState(ObjectInputStream, Fqn) - Method in class org.jboss.cache.statetransfer.StateTransferManager
Set the portion of the cache rooted in targetRoot to match the given state.
setStateException - Variable in class org.jboss.cache.remoting.jgroups.CacheMessageListener
Reference to an exception that was raised during state installation on this node.
setStateRetrievalTimeout(long) - Method in class org.jboss.cache.config.Configuration
 
setStateRetrievalTimeout(long) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setStateRetrievalTimeout(long) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Set the state transfer timeout (see LegacyConfiguration.getStateRetrievalTimeout())
setStateSet(boolean) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
setStatisticsEnabled(boolean) - Method in class org.jboss.cache.interceptors.Interceptor
 
setStatisticsEnabled(boolean) - Method in interface org.jboss.cache.interceptors.InterceptorMBean
Enables an interceptor's cache statistics If true, the interceptor will capture statistics and make them available through the mbean.
setStatus(Region.Status) - Method in interface org.jboss.cache.Region
A mechanism to set status of a region, more fine grained control than just setActive();
setStatus(Region.Status) - Method in class org.jboss.cache.RegionImpl
 
setSuccessful(boolean) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setSuppressLocking(boolean) - Method in class org.jboss.cache.config.Option
Suppresses acquiring locks for the given invocation.
setSyncCommitPhase(boolean) - Method in class org.jboss.cache.config.Configuration
 
setSyncCommitPhase(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setSyncCommitPhase(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setSyncReplTimeout(long) - Method in class org.jboss.cache.config.Configuration
 
setSyncReplTimeout(long) - Method in class org.jboss.cache.config.Option
Used to override the value in Configuration.getSyncReplTimeout() (used when cache mode is either Configuration.CacheMode.REPL_SYNC or Configuration.CacheMode.INVALIDATION_SYNC) for this specific invocation.
setSyncReplTimeout(long) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setSyncReplTimeout(long) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets the default maximum wait time for synchronous replication to receive all results
setSyncRollbackPhase(boolean) - Method in class org.jboss.cache.config.Configuration
 
setSyncRollbackPhase(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setSyncRollbackPhase(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setTable(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setTargetFqn(Fqn) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setterMethod(Class, Class) - Static method in class org.jboss.cache.util.BeanUtils
Returns a Method object corresponding to a setter that sets an instance of componentClass from target.
setterName(String) - Static method in class org.jboss.cache.util.BeanUtils
Retrieves a setter name based on a field name passed in
setterName(Class) - Static method in class org.jboss.cache.util.BeanUtils
Returns a setter for a given class
setTimeout(long) - Method in class org.jboss.cache.loader.ClusteredCacheLoaderConfig
 
setTimeout(int) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
setTimeToLiveSeconds(int) - Method in class org.jboss.cache.eviction.ExpirationConfiguration
 
setTimeToLiveSeconds(int) - Method in class org.jboss.cache.eviction.LRUConfiguration
 
setTransaction(Transaction) - Method in class org.jboss.cache.InvocationContext
Sets the transaction associated with this invocation
setTransaction(Transaction) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setTransaction(Transaction) - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Just used for unit tests
setTransaction(Transaction) - Method in class org.jboss.cache.transaction.TransactionEntry
Sets the local transaction for this entry.
setTransactionalContext(Transaction, GlobalTransaction, InvocationContext) - Method in class org.jboss.cache.interceptors.BaseTransactionalContextInterceptor
 
setTransactionManager(TransactionManager) - Method in class org.jboss.cache.config.RuntimeConfig
 
setTransactionManager(TransactionManager) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setTransactionManager(TransactionManager) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setTransactionManagerLookupClass(String) - Method in class org.jboss.cache.config.Configuration
 
setTransactionManagerLookupClass(String) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setTransactionManagerLookupClass(String) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets the class of the TransactionManagerLookup impl.
setTransactionTimeout(int) - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Change the transaction timeout for transactions started by the calling thread with the DummyBaseTransactionManager.begin() method.
setTransactionTimeout(int) - Method in class org.jboss.cache.transaction.DummyTransaction
Change the transaction timeout for transactions started by the calling thread with the DummyBaseTransactionManager.begin() method.
setTransactionTimeout(int) - Method in class org.jboss.cache.transaction.DummyUserTransaction
Change the transaction timeout for transactions started by the calling thread with the DummyUserTransaction.begin() method.
setTransactionWorkSpace(TransactionWorkspace) - Method in class org.jboss.cache.transaction.OptimisticTransactionEntry
 
setTxHasMods(boolean) - Method in class org.jboss.cache.InvocationContext
 
setType(Modification.ModificationType) - Method in class org.jboss.cache.Modification
Sets the type of modification.
setType(Event.Type) - Method in class org.jboss.cache.notifications.event.EventImpl
 
setUpdateNodeSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setUpdateTableSql(String) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
This method will create an EvictionQueue implementation and prepare it for use.
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.ElementSizeAlgorithm
 
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.ExpirationAlgorithm
 
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.FIFOAlgorithm
 
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.LFUAlgorithm
Will create a LFUQueue to be used as the underlying eviction queue.
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.LRUAlgorithm
 
setupEvictionQueue(Region) - Method in class org.jboss.cache.eviction.MRUAlgorithm
 
setUseAsyncPut(boolean) - Method in class org.jboss.cache.loader.AsyncCacheLoaderConfig
 
setUseInterceptorMbeans(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setUseInterceptorMbeans(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Deprecated. use LegacyConfiguration.setExposeManagementStatistics(boolean)
setUseLazyDeserialization(boolean) - Method in class org.jboss.cache.config.Configuration
 
setUseRegionBasedMarshalling(boolean) - Method in class org.jboss.cache.config.Configuration
Deprecated. 
setUseRegionBasedMarshalling(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setUseRegionBasedMarshalling(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
Sets whether marshalling uses scoped class loaders on a per region basis.
setUseReplQueue(boolean) - Method in class org.jboss.cache.config.Configuration
 
setUseReplQueue(boolean) - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
setUseReplQueue(boolean) - Method in interface org.jboss.cache.jmx.LegacyConfiguration
 
setUsingEvictions(boolean) - Method in class org.jboss.cache.RegionManager
Sets if evictions are processed.
setUsingMultiplexer(boolean) - Method in class org.jboss.cache.config.Configuration
 
setValid(boolean, boolean) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setValid(boolean, boolean) - Method in interface org.jboss.cache.NodeSPI
Sets the validity of a node.
setValid(boolean, boolean) - Method in class org.jboss.cache.UnversionedNode
 
setValue(Object) - Method in class org.jboss.cache.Modification
Sets the modification value.
setValue(Object, String, Object) - Static method in class org.jboss.cache.util.reflect.ReflectionUtil
 
setValues(Object, Map<?, ?>, boolean) - Static method in class org.jboss.cache.factories.XmlConfigurationParser
 
setVersion(DataVersion) - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
setVersion(DataVersion) - Method in interface org.jboss.cache.NodeSPI
Sets the data version of this node if versioning is supported.
setVersion(DataVersion) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Sets the data version of this workspace node.
setVersion(DataVersion) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
setVersion(DataVersion) - Method in class org.jboss.cache.UnversionedNode
 
setVersion(DataVersion) - Method in class org.jboss.cache.VersionedNode
Sets the version id of this node.
setVersioningImplicit(boolean) - Method in interface org.jboss.cache.optimistic.TransactionWorkspace
Sets if versioning is implicit for a given tx.
setVersioningImplicit(boolean) - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
setVersioningImplicit(boolean) - Method in interface org.jboss.cache.optimistic.WorkspaceNode
Sets whether versioning for the WorkspaceNode instance in the current transaction is implicit (i.e., using DefaultDataVersion rather than a custom DataVersion passed in using Option.setDataVersion(DataVersion))
setVersioningImplicit(boolean) - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
setWakeupIntervalSeconds(int) - Method in class org.jboss.cache.config.EvictionConfig
 
setWarnNoExpirationKey(boolean) - Method in class org.jboss.cache.eviction.ExpirationConfiguration
Sets if the algorithm should warn if a expiration key is missing for a node.
setWriterIfNotNull(Object) - Method in class org.jboss.cache.lock.LockMap
Adding a writer owner.
setXmlValues(Configuration, Map<String, Element>) - Method in class org.jboss.cache.factories.XmlConfigurationParser
 
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
This method will check whether the given node should be evicted or not.
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.ElementSizeAlgorithm
 
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.ExpirationAlgorithm
 
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.FIFOAlgorithm
For FIFO, a node should be evicted if the queue size is >= to the configured maxNodes size.
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.LFUAlgorithm
 
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.LRUAlgorithm
 
shouldEvictNode(NodeEntry) - Method in class org.jboss.cache.eviction.MRUAlgorithm
 
signalWaiters() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade.ReaderLock
 
signalWaiters() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade.WriterLock
 
SimpleLock - Class in org.jboss.cache.lock
Simple lock that does not differentiate read and write lock.
SimpleLock() - Constructor for class org.jboss.cache.lock.SimpleLock
 
SimpleReadWriteLock - Class in org.jboss.cache.lock
 
SimpleReadWriteLock() - Constructor for class org.jboss.cache.lock.SimpleReadWriteLock
 
SingletonStoreCacheLoader - Class in org.jboss.cache.loader
SingletonStoreCacheLoader is a delegating cache loader used for situations when only one node should interact with the underlying store.
SingletonStoreCacheLoader() - Constructor for class org.jboss.cache.loader.SingletonStoreCacheLoader
Empty constructor so that it can instantiated using reflection.
SingletonStoreCacheLoader(SingletonStoreDefaultConfig) - Constructor for class org.jboss.cache.loader.SingletonStoreCacheLoader
Protected constructor which should only be used from unit tests.
SingletonStoreCacheLoader.PushStateException - Exception in org.jboss.cache.loader
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
SingletonStoreCacheLoader.PushStateException(String, Throwable) - Constructor for exception org.jboss.cache.loader.SingletonStoreCacheLoader.PushStateException
 
SingletonStoreCacheLoader.PushStateException(Throwable) - Constructor for exception org.jboss.cache.loader.SingletonStoreCacheLoader.PushStateException
 
SingletonStoreCacheLoader.SingletonStoreListener - Class in org.jboss.cache.loader
Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
SingletonStoreCacheLoader.SingletonStoreListener() - Constructor for class org.jboss.cache.loader.SingletonStoreCacheLoader.SingletonStoreListener
 
SingletonStoreDefaultConfig - Class in org.jboss.cache.loader
Default singleton store cache loader configuration implementation, which is provided with the default singleton store cache loader implementation.
SingletonStoreDefaultConfig() - Constructor for class org.jboss.cache.loader.SingletonStoreDefaultConfig
Default constructor that sets default values for singleton store cache loader configuration taking in account that this configuration belongs to the default singleton store cache loader implementation.
SingletonStoreDefaultConfig(CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig) - Constructor for class org.jboss.cache.loader.SingletonStoreDefaultConfig
Constructor that sets the assumed values for the default singleton store cache loader implementation and also the properties, as per the properties section defined in the XML configuration.
size() - Method in class org.jboss.cache.Fqn
 
size() - Method in class org.jboss.cache.lock.ThreadLocalMap
 
size() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
size() - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.jboss.cache.util.DeltaMap
 
size() - Method in class org.jboss.cache.util.MapCopy
 
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.CacheMgmtInterceptor
 
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
if this is a shared cache loader and the call is of remote origin, pass up the chain
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.DataGravitatorInterceptor
 
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.InvalidationInterceptor
 
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.MethodDispacherInterceptor
Each interceptor should extend this if it does not need any processing for current call.
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.OptimisticReplicationInterceptor
 
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.PessimisticLockInterceptor
 
skipMethodCall(InvocationContext) - Method in class org.jboss.cache.interceptors.ReplicationInterceptor
 
skipReplicationOfTransactionMethod(InvocationContext) - Method in class org.jboss.cache.interceptors.BaseRpcInterceptor
It does not make sense replicating a transaction method(commit, rollback, prepare) if one of the following: - call was not initiated here, but on other member of the cluster - there is no transaction.
SortedEvictionQueue - Interface in org.jboss.cache.eviction
Sorted Eviction Queue implementation.
start() - Method in interface org.jboss.cache.Cache
Lifecycle method that starts the cache loader, starts cache replication, starts the region manager, etc., and (if configured) warms the cache using a state transfer or cache loader preload.
start() - Method in class org.jboss.cache.CacheImpl
Lifecyle method.
start() - Method in class org.jboss.cache.CacheManagerImpl
 
start() - Method in class org.jboss.cache.cluster.ReplicationQueue
Starts the asynchronous flush queue.
start() - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
Start - Annotation Type in org.jboss.cache.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache starts.
start() - Method in class org.jboss.cache.factories.ComponentRegistry
Starts all components that contain the Start annotation.
start() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
start() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
start() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
start() - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
start() - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
start() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
start() - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
start() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Opens the JE environment and the database specified by the configuration string.
start() - Method in class org.jboss.cache.loader.C3p0ConnectionFactory
 
start() - Method in interface org.jboss.cache.loader.CacheLoader
Lifecycle method, called when the cache loader is started.
start() - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
start() - Method in interface org.jboss.cache.loader.ConnectionFactory
 
start() - Method in class org.jboss.cache.loader.JDBCCacheLoader
Start is overwritten for the sake of backward compatibility only.
start() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Opens the environment and the database specified by the configuration string.
start() - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
start() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
start() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
start() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
start() - Method in class org.jboss.cache.RegionManager
 
start() - Method in interface org.jboss.cache.RPCManager
Starts the RPCManager by connecting the underlying JGroups channel (if configured for replication).
start() - Method in class org.jboss.cache.RPCManagerImpl
 
start() - Method in interface org.jboss.cache.TreeCacheViewMBean
 
startAllowed() - Method in enum org.jboss.cache.CacheStatus
 
startCacheLoader() - Method in class org.jboss.cache.loader.CacheLoaderManager
 
STARTED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The lifecycle method start has completed
startEvictionThread() - Method in class org.jboss.cache.RegionManager
Starts the eviction processing thread.
STARTING - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The lifecycle method start has been invoked
startInterceptor() - Method in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
startInterceptor() - Method in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
startRead() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
startReadFromNewReader() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
startReadFromWaitingReader() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
startWrite() - Method in class org.jboss.cache.lock.NonBlockingWriterLock
 
startWrite() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
startWriteFromNewWriter() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
startWriteFromWaitingWriter() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
STATE_TRANSFER_VERSION - Static variable in class org.jboss.cache.statetransfer.DefaultStateTransferGenerator
 
stateProducingFailed(Throwable) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
stateReceivedSuccess() - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
stateReceivingFailed(Throwable) - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
StateTransferFactory - Class in org.jboss.cache.statetransfer
Factory class able to create StateTransferGenerator and StateTransferIntegrator instances.
StateTransferFactory() - Constructor for class org.jboss.cache.statetransfer.StateTransferFactory
 
StateTransferGenerator - Interface in org.jboss.cache.statetransfer
 
StateTransferIntegrator - Interface in org.jboss.cache.statetransfer
 
StateTransferManager - Class in org.jboss.cache.statetransfer
 
StateTransferManager() - Constructor for class org.jboss.cache.statetransfer.StateTransferManager
 
StateTransferManager(CacheSPI) - Constructor for class org.jboss.cache.statetransfer.StateTransferManager
 
stop() - Method in class org.jboss.cache.buddyreplication.BuddyManager
Stops the buddy manager and the related async thread.
stop() - Method in interface org.jboss.cache.Cache
Lifecycle method that stops the cache, including replication, clustering, cache loading, notifications, etc., and clears all cache in-memory state.
stop() - Method in class org.jboss.cache.CacheImpl
Lifecycle method.
stop() - Method in class org.jboss.cache.CacheManagerImpl
 
stop() - Method in class org.jboss.cache.cluster.ReplicationQueue
Stops the asynchronous flush queue.
stop() - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
stop() - Method in class org.jboss.cache.eviction.EvictionTimerTask
 
Stop - Annotation Type in org.jboss.cache.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache stops.
stop() - Method in class org.jboss.cache.factories.ComponentRegistry
Stops all components that contain the Stop annotation.
stop() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
stop() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
stop() - Method in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
 
stop() - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
stop() - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
stop() - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
stop() - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
stop() - Method in class org.jboss.cache.loader.bdbje.BdbjeCacheLoader
Closes the JE databases and environment, and nulls references to them.
stop() - Method in class org.jboss.cache.loader.C3p0ConnectionFactory
 
stop() - Method in interface org.jboss.cache.loader.CacheLoader
Lifecycle method, called when the cache loader is stopped.
stop() - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
stop() - Method in interface org.jboss.cache.loader.ConnectionFactory
 
stop() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
Closes the databases and environment, and nulls references to them.
stop() - Method in class org.jboss.cache.loader.ManagedConnectionFactory
 
stop() - Method in class org.jboss.cache.loader.tcp.TcpCacheServer
 
stop() - Method in interface org.jboss.cache.loader.tcp.TcpCacheServerMBean
 
stop() - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
stop() - Method in class org.jboss.cache.RegionManager
 
stop() - Method in interface org.jboss.cache.RPCManager
Stops the RPCDispatcher and frees resources.
stop() - Method in class org.jboss.cache.RPCManagerImpl
 
stop() - Method in interface org.jboss.cache.TreeCacheViewMBean
 
stopAllowed() - Method in enum org.jboss.cache.CacheStatus
 
stopCacheLoader() - Method in class org.jboss.cache.loader.CacheLoaderManager
 
stopEvictionThread() - Method in class org.jboss.cache.RegionManager
Stops the eviction processing thread
STOPPED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The lifecycle method stop has completed
STOPPING - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The lifecycle method stop has been invoked
STORE_ENTIRE_STATE - Static variable in interface org.jboss.cache.loader.tcp.TcpCacheOperations
 
storeAttributes(Fqn, Map) - Method in class org.jboss.cache.loader.FileCacheLoader
 
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
storeEntireState(ObjectInputStream) - Method in interface org.jboss.cache.loader.CacheLoader
Stores the entire state for this cache by reading it from a provided ObjectInputStream.
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
storeEntireState(ObjectInputStream) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
storeObject(Fqn, Object) - Method in interface org.jboss.cache.loader.CacheLoaderAop
Stores an object under a given key in the persistent store.
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.AbstractCacheLoader
 
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.AbstractDelegatingCacheLoader
 
storeState(Fqn, ObjectInputStream) - Method in interface org.jboss.cache.loader.CacheLoader
Stores the given portion of the cache tree's state in secondary storage.
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.ClusteredCacheLoader
 
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.LocalDelegatingCacheLoader
 
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.ReadOnlyDelegatingCacheLoader
 
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
storeState(Fqn, ObjectInputStream) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
STREAMING_DELIMITER_NODE - Static variable in class org.jboss.cache.statetransfer.StateTransferManager
 
stringToElement(String) - Static method in class org.jboss.cache.xml.XmlHelper
Converts a String representing an XML snippet into an Element.
StripedLock - Class in org.jboss.cache.lock
A simple implementation of lock striping, using Fqns as the keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
StripedLock() - Constructor for class org.jboss.cache.lock.StripedLock
This constructor just calls StripedLock.StripedLock(int) with a default concurrency value of 20.
StripedLock(int) - Constructor for class org.jboss.cache.lock.StripedLock
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
subtreeResult(List<NodeData>, Fqn) - Static method in class org.jboss.cache.buddyreplication.GravitateResult
Factory method that creates a GravitateResult with the data found and the backup fqn it was found in.
suspect(Address) - Method in class org.jboss.cache.RPCManagerImpl.MembershipListenerAdaptor
Called when a member is suspected.
SuspectException - Exception in org.jboss.cache
Thrown when a member is suspected during remote method invocation
SuspectException() - Constructor for exception org.jboss.cache.SuspectException
 
SuspectException(String) - Constructor for exception org.jboss.cache.SuspectException
 
SuspectException(String, Throwable) - Constructor for exception org.jboss.cache.SuspectException
 
suspend() - Method in class org.jboss.cache.transaction.DummyBaseTransactionManager
Suspend the association the calling thread has to a transaction, and return the suspended transaction.

T

table - Variable in class org.jboss.cache.loader.AdjListJDBCCacheLoaderConfig
 
tableExists(String, Connection) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
takeLastEventNode() - Method in interface org.jboss.cache.Region
Returns the most recent EvictedEventNode added to the event queue by Region.putNodeEvent(EvictedEventNode).
takeLastEventNode() - Method in class org.jboss.cache.RegionImpl
 
TcpCacheOperations - Interface in org.jboss.cache.loader.tcp
Statics that used to exist in the DelegatingCacheLoader class.
TcpCacheServer - Class in org.jboss.cache.loader.tcp
TCP-IP based CacheServer, setCache TcpDelegatingCacheLoader with host and port of this server
TcpCacheServer() - Constructor for class org.jboss.cache.loader.tcp.TcpCacheServer
 
TcpCacheServerMBean - Interface in org.jboss.cache.loader.tcp
StandardMBean interface for TcpCacheServer.
TcpDelegatingCacheLoader - Class in org.jboss.cache.loader
DelegatingCacheLoader implementation which delegates to a remote (not in the same VM) CacheImpl using TCP/IP for communication.
TcpDelegatingCacheLoader() - Constructor for class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
TcpDelegatingCacheLoaderConfig - Class in org.jboss.cache.loader
 
TcpDelegatingCacheLoaderConfig() - Constructor for class org.jboss.cache.loader.TcpDelegatingCacheLoaderConfig
 
testImmutability(String) - Method in class org.jboss.cache.config.ConfigurationComponent
Checks field modifications via setters
ThreadGate - Class in org.jboss.cache.util
A reclosable gate with timeout support.
ThreadGate() - Constructor for class org.jboss.cache.util.ThreadGate
 
ThreadLocalMap<K,V> - Class in org.jboss.cache.lock
Map which reduces concurrency and potential memory leaks for non-static ThreadLocals.
ThreadLocalMap() - Constructor for class org.jboss.cache.lock.ThreadLocalMap
 
TimeoutException - Exception in org.jboss.cache.lock
Thrown when a timeout occurred. used by operations with timeouts, e.g. lock acquisition, or waiting for responses from all members.
TimeoutException() - Constructor for exception org.jboss.cache.lock.TimeoutException
 
TimeoutException(String) - Constructor for exception org.jboss.cache.lock.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.jboss.cache.lock.TimeoutException
 
toArray() - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
toArray(T[]) - Method in class org.jboss.cache.util.concurrent.ConcurrentHashSet
 
toDebugString() - Method in class org.jboss.cache.util.DeltaMap
Returns a debug string.
toString() - Method in class org.jboss.cache.buddyreplication.BuddyGroup
 
toString() - Method in class org.jboss.cache.buddyreplication.GravitateResult
 
toString() - Method in class org.jboss.cache.CacheImpl
Returns a debug string with few details.
toString(boolean) - Method in class org.jboss.cache.CacheImpl
Returns a debug string with optional details of contents.
toString() - Method in class org.jboss.cache.config.BuddyReplicationConfig.BuddyLocatorConfig
 
toString() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig.SingletonStoreConfig
 
toString() - Method in class org.jboss.cache.config.CacheLoaderConfig.IndividualCacheLoaderConfig
 
toString() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
toString() - Method in class org.jboss.cache.config.Option
 
toString() - Method in class org.jboss.cache.eviction.BaseEvictionAlgorithm
Returns debug information.
toString() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
 
toString() - Method in class org.jboss.cache.eviction.EvictedEventNode
 
toString() - Method in class org.jboss.cache.eviction.EvictionQueueList
 
toString() - Method in class org.jboss.cache.eviction.FIFOConfiguration
 
toString() - Method in class org.jboss.cache.eviction.LFUConfiguration
 
toString() - Method in class org.jboss.cache.eviction.LRUConfiguration
 
toString() - Method in class org.jboss.cache.eviction.MRUConfiguration
 
toString() - Method in class org.jboss.cache.eviction.MRUQueue
 
toString() - Method in class org.jboss.cache.eviction.NodeEntry
 
toString() - Method in class org.jboss.cache.Fqn
Returns this Fqn as a string, prefixing the first element with a Fqn.SEPARATOR and joining each subsequent element with a Fqn.SEPARATOR.
toString() - Method in class org.jboss.cache.interceptors.Interceptor
 
toString() - Method in class org.jboss.cache.interceptors.OrderedSynchronizationHandler
 
toString() - Method in class org.jboss.cache.invocation.CacheInvocationDelegate
 
toString() - Method in class org.jboss.cache.invocation.NodeInvocationDelegate
 
toString() - Method in class org.jboss.cache.InvocationContext
 
toString() - Method in class org.jboss.cache.loader.AsyncCacheLoader
 
toString() - Method in class org.jboss.cache.loader.ChainingCacheLoader
 
toString() - Method in class org.jboss.cache.loader.jdbm.JdbmCacheLoader
 
toString() - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader
Calls the underlying cache loader's operation if the current node is the coordinator.
toString() - Method in class org.jboss.cache.lock.IdentityLock
 
toString(boolean) - Method in class org.jboss.cache.lock.IdentityLock
 
toString(StringBuffer) - Method in class org.jboss.cache.lock.IdentityLock
 
toString(StringBuffer, boolean) - Method in class org.jboss.cache.lock.IdentityLock
 
toString() - Method in exception org.jboss.cache.lock.LockingException
 
toString() - Method in class org.jboss.cache.lock.LockStrategyRepeatableRead
 
toString() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
toString() - Method in exception org.jboss.cache.lock.TimeoutException
 
toString() - Method in class org.jboss.cache.marshall.InactiveRegionAwareRpcDispatcher
 
toString() - Method in class org.jboss.cache.marshall.MarshalledValue
 
toString() - Method in class org.jboss.cache.marshall.MethodCall
 
toString() - Method in class org.jboss.cache.marshall.NodeData
 
toString() - Method in class org.jboss.cache.marshall.NodeDataExceptionMarker
 
toString() - Method in class org.jboss.cache.marshall.NodeDataMarker
 
toString() - Method in class org.jboss.cache.Modification
Returns debug information about this modification.
toString() - Method in class org.jboss.cache.notifications.event.EventImpl
 
toString() - Method in class org.jboss.cache.optimistic.DefaultDataVersion
 
toString() - Method in class org.jboss.cache.optimistic.TransactionWorkspaceImpl
Returns debug information.
toString() - Method in class org.jboss.cache.optimistic.WorkspaceNodeImpl
 
toString() - Method in class org.jboss.cache.RegionImpl
 
toString() - Method in class org.jboss.cache.RegionManager
Returns a string containing debug information on every region.
toString() - Method in exception org.jboss.cache.ReplicationException
 
toString() - Method in exception org.jboss.cache.SuspectException
 
toString() - Method in class org.jboss.cache.transaction.GlobalTransaction
 
toString() - Method in class org.jboss.cache.transaction.OptimisticTransactionEntry
 
toString() - Method in class org.jboss.cache.transaction.TransactionEntry
Returns debug information about this transaction.
toString() - Method in class org.jboss.cache.transaction.TransactionTable
Returns summary debug information.
toString(boolean) - Method in class org.jboss.cache.transaction.TransactionTable
Returns detailed debug information.
toString() - Method in class org.jboss.cache.UnversionedNode
Returns a debug string.
toString() - Method in class org.jboss.cache.util.BitEncodedIntegerSet
 
toString() - Method in class org.jboss.cache.util.Util.MapModifications
 
trace - Variable in class org.jboss.cache.interceptors.Interceptor
 
trace - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
trace - Static variable in class org.jboss.cache.UnversionedNode
 
TransactionalEvent - Interface in org.jboss.cache.notifications.event
An event type that includes a transaction context - if one exists - as well as a boolean as to whether the call originated locally or remotely.
TransactionCompleted - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and the transaction completes, either with a commit or a rollback.
TransactionCompletedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with TransactionCompleted.
TransactionEntry - Class in org.jboss.cache.transaction
Information associated with a GlobalTransaction about the transaction state.
TransactionEntry(Transaction) - Constructor for class org.jboss.cache.transaction.TransactionEntry
 
TransactionManagerFactory - Class in org.jboss.cache.factories
Uses a number of mechanisms to retrieve a transaction manager.
TransactionManagerFactory() - Constructor for class org.jboss.cache.factories.TransactionManagerFactory
 
TransactionManagerLookup - Interface in org.jboss.cache.transaction
Factory interface, allows Cache to use different transactional systems.
TransactionRegistered - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and registers a Synchronization with a registered TransactionManager.
TransactionRegisteredEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with TransactionRegistered.
transactions - Variable in class org.jboss.cache.interceptors.ActivationInterceptor
List that we have registered for
transactions - Variable in class org.jboss.cache.loader.AbstractCacheLoader
HashMap>.
TransactionTable - Class in org.jboss.cache.transaction
Maintains the mapping between a local Transaction and a GlobalTransaction.
TransactionTable() - Constructor for class org.jboss.cache.transaction.TransactionTable
 
TransactionWorkspace<K,V> - Interface in org.jboss.cache.optimistic
Used to contain a copy of the tree being worked on within the scope of a given transaction.
TransactionWorkspaceImpl<K,V> - Class in org.jboss.cache.optimistic
Contains a mapping of Fqn to WorkspaceNodes.
TransactionWorkspaceImpl() - Constructor for class org.jboss.cache.optimistic.TransactionWorkspaceImpl
 
transformFqns(MethodCall) - Method in class org.jboss.cache.buddyreplication.BuddyManager
Introspects method call for Fqns and changes them such that they are under the current buddy group's backup subtree (e.g., /_buddy_backup_/my_host:7890/) rather than the root (/).
transformFqns(MethodCall, boolean) - Method in class org.jboss.cache.buddyreplication.BuddyManager
 
TreeCacheViewMBean - Interface in org.jboss.cache
MBean interface.
tryLock(long, TimeUnit) - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade.ReaderLock
 
tryLock(long, TimeUnit) - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade.WriterLock
 
tryLock() - Method in class org.jboss.cache.lock.SemaphoreLock
 
tryLock(long, TimeUnit) - Method in class org.jboss.cache.lock.SemaphoreLock
 
tx_map - Variable in class org.jboss.cache.transaction.TransactionTable
Mapping between local (javax.transaction.Transaction) and GlobalTransactions.
tx_mgr - Variable in class org.jboss.cache.interceptors.ActivationInterceptor
 
tx_mgr - Variable in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
tx_table - Variable in class org.jboss.cache.interceptors.ActivationInterceptor
 
tx_table - Variable in class org.jboss.cache.interceptors.CacheStoreInterceptor
 
TxInterceptor - Class in org.jboss.cache.interceptors
This interceptor is the new default at the head of all interceptor chains, and makes transactional attributes available to all interceptors in the chain.
TxInterceptor() - Constructor for class org.jboss.cache.interceptors.TxInterceptor
 
TxInterceptorMBean - Interface in org.jboss.cache.interceptors
Interface capturing transaction statistics
txManager - Variable in class org.jboss.cache.interceptors.BaseTransactionalContextInterceptor
 
txManager - Variable in class org.jboss.cache.interceptors.OptimisticInterceptor
 
txMods - Variable in class org.jboss.cache.interceptors.InvalidationInterceptor
 
txs - Variable in class org.jboss.cache.transaction.TransactionTable
Mappings between GlobalTransactions and modifications.
txTable - Variable in class org.jboss.cache.interceptors.BaseTransactionalContextInterceptor
 
txTable - Variable in class org.jboss.cache.interceptors.InvalidationInterceptor
 
txTable - Variable in class org.jboss.cache.interceptors.OptimisticInterceptor
 

U

unbind(Name) - Method in class org.jboss.cache.transaction.DummyContext
Unbinds the named object.
unbind(String) - Method in class org.jboss.cache.transaction.DummyContext
Unbinds the named object.
unblock() - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
unblock() - Method in class org.jboss.cache.RPCManagerImpl.MembershipListenerAdaptor
Indicates that a channel has received a UNBLOCK event from FLUSH protocol.
unblockChannelMethodLocal - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
unblockChannelMethodLocal_id - Static variable in class org.jboss.cache.marshall.MethodDeclarations
 
undeleteWorkspaceNode(WorkspaceNode, TransactionWorkspace) - Method in class org.jboss.cache.interceptors.OptimisticInterceptor
 
undeleteWorkspaceNode(WorkspaceNode, WorkspaceNode) - Method in class org.jboss.cache.interceptors.OptimisticInterceptor
Undeletes a node that already exists in the workspace, by setting appropriate flags and re-adding to parent's child map.
undoOperations(CacheSPI) - Method in class org.jboss.cache.transaction.TransactionEntry
Posts all undo operations to the CacheImpl.
UNIQUE_ID_KEY - Static variable in class org.jboss.cache.jmx.JmxUtil
 
unlock() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade.ReaderLock
 
unlock() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade.WriterLock
 
unlock() - Method in class org.jboss.cache.lock.SemaphoreLock
 
UnlockInterceptor - Class in org.jboss.cache.interceptors
Deprecated. 
UnlockInterceptor() - Constructor for class org.jboss.cache.interceptors.UnlockInterceptor
Deprecated.  
unmarkNodeCurrentlyInUse(Fqn) - Method in interface org.jboss.cache.Region
Adds an event to the eviction queue indicating that a node is no longer in use.
unmarkNodeCurrentlyInUse(Fqn) - Method in class org.jboss.cache.RegionImpl
 
unmarshall(InputStream) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
 
unmarshallDefaultDataVersion(ObjectInputStream) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
unmarshalledMap(Set) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
UnmarshalledReferences - Class in org.jboss.cache.marshall
An efficient array-based list of referenced objects, using the reference id as a subscript for the array.
UnmarshalledReferences() - Constructor for class org.jboss.cache.marshall.UnmarshalledReferences
 
unregisterCacheMBean(MBeanServer, String) - Static method in class org.jboss.cache.jmx.JmxUtil
 
unregisterComponent(Class<?>) - Method in class org.jboss.cache.factories.ComponentRegistry
Removes a component from the registry.
unregisterComponent(String) - Method in class org.jboss.cache.factories.ComponentRegistry
Removes a component from the registry.
unregisterConfiguration(String) - Method in interface org.jboss.cache.config.ConfigurationRegistry
Unregisters the named configuration.
unregisterConfiguration(String) - Method in class org.jboss.cache.config.XmlParsingConfigurationRegistry
 
unregisterContextClassLoader() - Method in interface org.jboss.cache.Region
Unregisters a registered ClassLoaders for this region.
unregisterContextClassLoader() - Method in class org.jboss.cache.RegionImpl
 
UNREGISTERED - Static variable in interface org.jboss.cache.jmx.CacheJmxWrapperMBean
The MBean has been instantiated but has not completed MBeanRegistration.postRegister
unregisterInterceptors() - Method in class org.jboss.cache.jmx.CacheJmxWrapper
 
unregisterInterceptors(MBeanServer, List<Interceptor>, String) - Static method in class org.jboss.cache.jmx.JmxUtil
 
UnversionedNode<K,V> - Class in org.jboss.cache
Basic data node class.
UnversionedNode() - Constructor for class org.jboss.cache.UnversionedNode
Constructs a new node with an FQN of Root.
UnversionedNode(Object, Fqn, Map, boolean, CacheSPI) - Constructor for class org.jboss.cache.UnversionedNode
Constructs a new node with a name, etc.
updateDependencies() - Method in class org.jboss.cache.factories.ComponentRegistry
Updates (re-injects) any dependencies needed by all components already in the registry.
updateNode(Fqn, Map<Object, Object>) - Method in class org.jboss.cache.loader.AdjListJDBCCacheLoader
Updates a node in the database.
upgrade(Object) - Method in class org.jboss.cache.lock.LockMap
Upgrading current reader ownership to writer one.
UpgradeException - Exception in org.jboss.cache.lock
Used when a read-lock cannot be upgraded to a write-lock
UpgradeException(String) - Constructor for exception org.jboss.cache.lock.UpgradeException
Constructor for UpgradeException.
UpgradeException(String, Throwable) - Constructor for exception org.jboss.cache.lock.UpgradeException
 
upgradeLockAttempt(long) - Method in interface org.jboss.cache.lock.LockStrategy
Attempt to upgrade the current read lock to write lock with msecs timeout.
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.LockStrategyNone
 
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.LockStrategyReadCommitted
 
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.LockStrategyReadUncommitted
 
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.LockStrategyRepeatableRead
 
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.LockStrategySerializable
 
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
Attempt to obtain an upgrade to writer lock.
upgradeLockAttempt(long) - Method in class org.jboss.cache.lock.SimpleLock
 
upgraderLocal_ - Static variable in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
useCacheStore - Variable in class org.jboss.cache.interceptors.CacheLoaderInterceptor
True if CacheStoreInterceptor is in place.
useChainingCacheLoader() - Method in class org.jboss.cache.config.CacheLoaderConfig
 
useRefs - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
useRegionBasedMarshalling - Variable in class org.jboss.cache.marshall.AbstractMarshaller
 
usingOptimisticInvalidation - Variable in class org.jboss.cache.interceptors.CacheLoaderInterceptor
 
Util - Class in org.jboss.cache.util
General utility methods used throughout the JBC code base.
Util.MapModifications - Class in org.jboss.cache.util
Static inner class that holds 3 maps - for data added, removed and modified.
Util.MapModifications() - Constructor for class org.jboss.cache.util.Util.MapModifications
 

V

validate() - Method in interface org.jboss.cache.config.EvictionPolicyConfig
Validate the configuration.
validate() - Method in class org.jboss.cache.eviction.ElementSizeConfiguration
Requires a positive maxElementsPerNode value or ConfigurationException is thrown.
validate() - Method in class org.jboss.cache.eviction.EvictionPolicyConfigBase
 
validate() - Method in class org.jboss.cache.eviction.FIFOConfiguration
Requires a positive maxNodes value or ConfigurationException is thrown.
validate() - Method in class org.jboss.cache.eviction.LRUConfiguration
Requires a positive timeToLiveSeconds value or ConfigurationException is thrown.
validate() - Method in class org.jboss.cache.eviction.MRUConfiguration
Requires a positive maxNodes value or ConfigurationException is thrown.
validate() - Method in class org.jboss.cache.eviction.NullEvictionPolicyConfig
No-op
valueOf(String) - Static method in enum org.jboss.cache.CacheStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.config.Configuration.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.config.Configuration.NodeLockingScheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.config.Configuration.ShutdownHookBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.eviction.NodeEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.factories.ComponentRegistry.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.lock.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.lock.NodeLock.LockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.Modification.ModificationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.NodeFactory.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.notifications.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.notifications.event.NodeModifiedEvent.ModificationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.Region.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jboss.cache.Region.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.jboss.cache.CacheStatus
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.config.Configuration.CacheMode
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.config.Configuration.NodeLockingScheme
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.config.Configuration.ShutdownHookBehavior
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.eviction.NodeEventType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.factories.ComponentRegistry.State
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.lock.IsolationLevel
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.lock.NodeLock.LockType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Method in class org.jboss.cache.lock.ThreadLocalMap
 
values() - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
values() - Static method in enum org.jboss.cache.Modification.ModificationType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.NodeFactory.NodeType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.notifications.event.Event.Type
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.notifications.event.NodeModifiedEvent.ModificationType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.Region.Status
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.jboss.cache.Region.Type
Returns an array containing the constants of this enum type, in the order they're declared.
Version - Class in org.jboss.cache
Contains version information about this release of JBoss Cache.
Version() - Constructor for class org.jboss.cache.Version
 
version - Static variable in class org.jboss.cache.Version
 
Version.Retro - Class in org.jboss.cache
Retroweaver version info.
Version.Retro() - Constructor for class org.jboss.cache.Version.Retro
 
VersionAwareMarshaller - Class in org.jboss.cache.marshall
A delegate to various other marshallers like CacheMarshaller200.
VersionAwareMarshaller() - Constructor for class org.jboss.cache.marshall.VersionAwareMarshaller
 
VersionedNode<K,V> - Class in org.jboss.cache
VersionedNode extends the UnversionedNode by adding a DataVersion property.
VersionedNode(Fqn, NodeSPI<K, V>, Map<K, V>, CacheSPI<K, V>) - Constructor for class org.jboss.cache.VersionedNode
 
viewAccepted(View) - Method in class org.jboss.cache.RPCManagerImpl.MembershipListenerAdaptor
 
viewChange(ViewChangedEvent) - Method in class org.jboss.cache.loader.SingletonStoreCacheLoader.SingletonStoreListener
The cluster formation changed, so determine whether the current node stopped being the coordinator or became the coordinator.
ViewChanged - Annotation Type in org.jboss.cache.notifications.annotation
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology changes (i.e., a member joins or leaves the cluster).
ViewChangedEvent - Interface in org.jboss.cache.notifications.event
This event is passed in to any method annotated with ViewChanged.

W

waitForState() - Method in class org.jboss.cache.remoting.jgroups.CacheMessageListener
 
WAKEUP_DEFAULT - Static variable in class org.jboss.cache.config.EvictionConfig
 
WAKEUP_INTERVAL_SECONDS - Static variable in class org.jboss.cache.config.EvictionConfig
 
wire() - Method in class org.jboss.cache.factories.ComponentRegistry
Injects dependencies to all components that require injection.
wireDependencies(Object) - Method in class org.jboss.cache.factories.ComponentRegistry
Wires an object instance with dependencies annotated with the Inject annotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in the ComponentRegistry.
WorkspaceNode<K,V> - Interface in org.jboss.cache.optimistic
Represents a type of Node that is to be copied into a TransactionWorkspace for optimistically locked nodes.
WorkspaceNodeImpl<K,V> - Class in org.jboss.cache.optimistic
Wraps an ordinary Node and adds versioning and other meta data to it.
WorkspaceNodeImpl(NodeSPI<K, V>, TransactionWorkspace) - Constructor for class org.jboss.cache.optimistic.WorkspaceNodeImpl
Constructs with a node and workspace.
wrapMap(Map<Object, Object>, Set<MarshalledValue>, InvocationContext) - Method in class org.jboss.cache.interceptors.MarshalledValueInterceptor
 
write(byte[], int, int) - Method in class org.jboss.cache.util.ExposedByteArrayOutputStream
 
write(int) - Method in class org.jboss.cache.util.ExposedByteArrayOutputStream
 
writeExternal(ObjectOutput) - Method in class org.jboss.cache.Fqn
 
writeExternal(ObjectOutput) - Method in class org.jboss.cache.marshall.MarshalledValue
 
writeExternal(ObjectOutput) - Method in class org.jboss.cache.marshall.MarshalledValueMap
 
writeExternal(ObjectOutput) - Method in class org.jboss.cache.marshall.NodeData
 
writeExternal(ObjectOutput) - Method in class org.jboss.cache.marshall.NodeDataExceptionMarker
 
writeExternal(ObjectOutput) - Method in class org.jboss.cache.Modification
Writes data to an external stream.
writeExternal(ObjectOutput) - Method in class org.jboss.cache.transaction.GlobalTransaction
 
writeLock() - Method in interface org.jboss.cache.lock.LockStrategy
Return a write lock object.
writeLock() - Method in class org.jboss.cache.lock.LockStrategyNone
 
writeLock() - Method in class org.jboss.cache.lock.LockStrategyReadCommitted
 
writeLock() - Method in class org.jboss.cache.lock.LockStrategyReadUncommitted
 
writeLock() - Method in class org.jboss.cache.lock.LockStrategyRepeatableRead
 
writeLock() - Method in class org.jboss.cache.lock.LockStrategySerializable
 
writeLock() - Method in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
writeLock() - Method in class org.jboss.cache.lock.SimpleLock
 
writeReference(ObjectOutputStream, int) - Method in class org.jboss.cache.marshall.CacheMarshaller200
Writes a reference to a given object output stream.
writeReference(ObjectOutputStream, int) - Method in class org.jboss.cache.marshall.CacheMarshaller210
This version of writeReference is written to solve JBCACHE-1211, where references are encoded as ints rather than shorts.
writerLock_ - Variable in class org.jboss.cache.lock.ReadWriteLockWithUpgrade
 
writerOwner() - Method in class org.jboss.cache.lock.LockMap
 
writeUnsignedInt(ObjectOutputStream, int) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
writeUnsignedInt(ObjectOutputStream, int) - Method in class org.jboss.cache.marshall.CacheMarshaller210
Writes an int in a variable-length format.
writeUnsignedLong(ObjectOutputStream, long) - Method in class org.jboss.cache.marshall.CacheMarshaller200
 
writeUnsignedLong(ObjectOutputStream, long) - Method in class org.jboss.cache.marshall.CacheMarshaller210
Writes an int in a variable-length format.

X

XmlConfigurationParser - Class in org.jboss.cache.factories
Reads in XMLconfiguration files and spits out a Configuration object.
XmlConfigurationParser() - Constructor for class org.jboss.cache.factories.XmlConfigurationParser
 
XmlHelper - Class in org.jboss.cache.xml
A simple XML utility class for reading configuration elements
XmlHelper() - Constructor for class org.jboss.cache.xml.XmlHelper
 
XmlParsingConfigurationRegistry - Class in org.jboss.cache.config
ConfigurationRegistry that obtains its initial set of configurations by parsing an XML document.
XmlParsingConfigurationRegistry(String) - Constructor for class org.jboss.cache.config.XmlParsingConfigurationRegistry
 

Z

ZERO - Static variable in class org.jboss.cache.optimistic.DefaultDataVersion
Version zero.

_

_addChild(GlobalTransaction, Fqn, Object, Node, boolean) - Method in class org.jboss.cache.CacheImpl
Compensating method to CacheImpl._remove(GlobalTransaction,Fqn,boolean).
_block() - Method in class org.jboss.cache.CacheImpl
 
_evict(Fqn) - Method in class org.jboss.cache.CacheImpl
Internal evict method called by eviction policy provider.
_evict(Fqn, DataVersion) - Method in class org.jboss.cache.CacheImpl
Internal evict method called by eviction policy provider.
_evictSubtree(Fqn) - Method in class org.jboss.cache.CacheImpl
Evicts the node at subtree along with all descendant nodes.
_exists(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_get(Fqn<?>) - Method in class org.jboss.cache.CacheImpl
Returns the raw data of the node; called externally internally.
_get(Fqn<?>, Object, boolean) - Method in class org.jboss.cache.CacheImpl
 
_get(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_getChildrenNames(Fqn<E>) - Method in class org.jboss.cache.CacheImpl
 
_getChildrenNames(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_getData(Fqn<?>) - Method in class org.jboss.cache.CacheImpl
Returns the raw data of the node; called externally internally.
_getKeys(Fqn<?>) - Method in class org.jboss.cache.CacheImpl
 
_lock(Fqn, NodeLock.LockType, boolean) - Method in class org.jboss.cache.CacheImpl
Should not be called.
_move(Fqn, Fqn) - Method in class org.jboss.cache.CacheImpl
Called by reflection
_print(Fqn) - Method in class org.jboss.cache.CacheImpl
Finds and returns the string value for the Fqn.
_put(GlobalTransaction, Fqn, Map, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_put(GlobalTransaction, Fqn, Map, boolean, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_put(GlobalTransaction, Fqn, Object, Object, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_put(GlobalTransaction, String, Map, boolean) - Method in class org.jboss.cache.CacheImpl
Internal put method.
_put(GlobalTransaction, Fqn, Map, boolean) - Method in class org.jboss.cache.CacheImpl
Internal put method.
_put(GlobalTransaction, Fqn, Map, boolean, boolean) - Method in class org.jboss.cache.CacheImpl
Internal put method.
_put(GlobalTransaction, String, Object, Object, boolean) - Method in class org.jboss.cache.CacheImpl
Internal put method.
_put(GlobalTransaction, Fqn, Object, Object, boolean) - Method in class org.jboss.cache.CacheImpl
Internal put method.
_put(Fqn, Object, Object) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_put(Fqn, Map<Object, Object>) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_put(List<Modification>) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_putForExternalRead(GlobalTransaction, Fqn, Object, Object, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_putForExternalRead(GlobalTransaction, Fqn, Object, Object) - Method in class org.jboss.cache.CacheImpl
 
_releaseAllLocks(Fqn) - Method in class org.jboss.cache.CacheImpl
Releases all locks for a FQN.
_remove(GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_remove(GlobalTransaction, Fqn, Object, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_remove(GlobalTransaction, String, boolean) - Method in class org.jboss.cache.CacheImpl
Internal remove method.
_remove(GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.CacheImpl
Internal remove method.
_remove(GlobalTransaction, Fqn, boolean, boolean) - Method in class org.jboss.cache.CacheImpl
 
_remove(GlobalTransaction, Fqn, boolean, boolean, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove a node.
_remove(GlobalTransaction, Fqn, boolean, boolean, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
Internal method to remove a node.
_remove(GlobalTransaction, String, Object, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove a key.
_remove(GlobalTransaction, Fqn, Object, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove a key.
_remove(Fqn, Object) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_remove(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_removeData(GlobalTransaction, Fqn, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
 
_removeData(GlobalTransaction, String, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove data from a node.
_removeData(GlobalTransaction, Fqn, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove data from a node.
_removeData(GlobalTransaction, Fqn, boolean, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove data from a node.
_removeData(GlobalTransaction, Fqn, boolean, boolean, boolean) - Method in class org.jboss.cache.CacheImpl
Internal method to remove data from a node.
_removeData(GlobalTransaction, Fqn, boolean, boolean, boolean, DataVersion) - Method in class org.jboss.cache.CacheImpl
Internal method to remove data from a node.
_removeData(Fqn) - Method in class org.jboss.cache.loader.TcpDelegatingCacheLoader
 
_replicate(MethodCall) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
 
_replicate(List<MethodCall>) - Method in class org.jboss.cache.invocation.RemoteCacheInvocationDelegate
Replicates a list of method calls.
_unblock() - Method in class org.jboss.cache.CacheImpl
 

A B C D E F G H I J K L M N O P R S T U V W X Z _

Copyright © 2008 JBoss, a division of Red Hat. All Rights Reserved.