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

A

AbstractCacheLoader - Class in org.infinispan.loaders
An abstract CacheLoader that holds common implementations for some methods
AbstractCacheLoader() - Constructor for class org.infinispan.loaders.AbstractCacheLoader
 
AbstractCacheLoaderConfig - Class in org.infinispan.loaders
Abstract base class for CacheLoaderConfigs.
AbstractCacheLoaderConfig() - Constructor for class org.infinispan.loaders.AbstractCacheLoaderConfig
 
AbstractCacheStore - Class in org.infinispan.loaders
An abstract CacheStore that holds common implementations for some methods
AbstractCacheStore() - Constructor for class org.infinispan.loaders.AbstractCacheStore
 
AbstractCacheStoreConfig - Class in org.infinispan.loaders
Configures AbstractCacheStore.
AbstractCacheStoreConfig() - Constructor for class org.infinispan.loaders.AbstractCacheStoreConfig
 
AbstractComponentFactory - Class in org.infinispan.factories
Factory that creates components used internally within Infinispan, and also wires dependencies into the components.
AbstractComponentFactory() - Constructor for class org.infinispan.factories.AbstractComponentFactory
Constructs a new ComponentFactory.
AbstractComponentRegistry - Class in org.infinispan.factories
A registry where components which have been created are stored.
AbstractComponentRegistry() - Constructor for class org.infinispan.factories.AbstractComponentRegistry
 
AbstractComponentRegistry.Component - Class in org.infinispan.factories
A wrapper representing a component in the registry
AbstractComponentRegistry.Component() - Constructor for class org.infinispan.factories.AbstractComponentRegistry.Component
 
AbstractConfigurationBean - Class in org.infinispan.config
Base superclass of Cache configuration classes that expose some properties that can be changed after the cache is started.
AbstractConfigurationBean() - Constructor for class org.infinispan.config.AbstractConfigurationBean
 
AbstractDataCommand - Class in org.infinispan.commands.read
 
AbstractDataCommand(Object) - Constructor for class org.infinispan.commands.read.AbstractDataCommand
 
AbstractDataCommand() - Constructor for class org.infinispan.commands.read.AbstractDataCommand
 
AbstractDelegatingAdvancedCache<K,V> - Class in org.infinispan
Similar to AbstractDelegatingCache, but for AdvancedCache.
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
 
AbstractDelegatingCache<K,V> - Class in org.infinispan
This is a convenient base class for implementing a cache delegate.
AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingCache
 
AbstractDelegatingStore - Class in org.infinispan.loaders.decorators
Simple delegate that delegates all calls.
AbstractDelegatingStore(CacheStore) - Constructor for class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
AbstractInternalCacheEntry - Class in org.infinispan.container.entries
An abstract internal cache entry that is typically stored in the data container
AbstractInvocationContext - Class in org.infinispan.context.impl
Common features of transaction and invocation contexts
AbstractInvocationContext() - Constructor for class org.infinispan.context.impl.AbstractInvocationContext
 
AbstractInvocationContext.ContextFlag - Enum in org.infinispan.context.impl
 
AbstractListenerImpl - Class in org.infinispan.notifications
Functionality common to both CacheManagerNotifierImpl and CacheNotifierImpl
AbstractListenerImpl() - Constructor for class org.infinispan.notifications.AbstractListenerImpl
 
AbstractListenerImpl.ListenerInvocation - Class in org.infinispan.notifications
Class that encapsulates a valid invocation for a given registered listener - containing a reference to the method to be invoked as well as the target object.
AbstractListenerImpl.ListenerInvocation(Object, Method, boolean) - Constructor for class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
AbstractLogImpl - Class in org.infinispan.util.logging
Abstract log implementation that handles message interpolation
AbstractLogImpl() - Constructor for class org.infinispan.util.logging.AbstractLogImpl
 
AbstractMap<K,V> - Class in org.infinispan.util
Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
AbstractMap() - Constructor for class org.infinispan.util.AbstractMap
 
AbstractMap.SimpleEntry<K,V> - Class in org.infinispan.util
 
AbstractMarshaller - Class in org.infinispan.marshall
Abstract marshaller
AbstractMarshaller() - Constructor for class org.infinispan.marshall.AbstractMarshaller
 
AbstractNamedCacheComponentFactory - Class in org.infinispan.factories
A component factory for creating components scoped per-cache.
AbstractNamedCacheComponentFactory() - Constructor for class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
AbstractNamedCacheConfigurationBean - Class in org.infinispan.config
Adds named cache specific features to the AbstractConfigurationBean.
AbstractNamedCacheConfigurationBean() - Constructor for class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
AbstractPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
An abstract lock container that creates and maintains a new lock per entry
AbstractPerEntryLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
AbstractStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A container for locks.
AbstractStripedLockContainer() - Constructor for class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
AbstractTransactionBoundaryCommand - Class in org.infinispan.commands.tx
An abstract transaction boundary command that holds a reference to a GlobalTransaction
AbstractTransactionBoundaryCommand() - Constructor for class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
AbstractTxInvocationContext - Class in org.infinispan.context.impl
Support class for TxInvocationContext.
AbstractTxInvocationContext() - Constructor for class org.infinispan.context.impl.AbstractTxInvocationContext
 
AbstractVisitor - Class in org.infinispan.commands
An abstract implementation of a Visitor that delegates all visit calls to a default handler which can be overridden.
AbstractVisitor() - Constructor for class org.infinispan.commands.AbstractVisitor
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.LockControlCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.SizeCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.tx.CommitCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.tx.PrepareCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.tx.RollbackCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in interface org.infinispan.commands.VisitableCommand
Accept a visitor, and return the result of accepting this visitor.
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.ClearCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.EvictCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.InvalidateCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.PutMapCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.RemoveCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.ReplaceCommand
 
acquireAllLocks(List<Object>, boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Acquires locks on keys passed in.
acquireGlobalLock(boolean) - Method in class org.infinispan.loaders.LockSupportCacheStore
Based on the supplied param, acquires a global read(false) or write (true) lock.
acquireLock(InvocationContext, Object) - Method in interface org.infinispan.factories.EntryFactory
Attempts to lock an entry if the lock isn't already held in the current scope, and records the lock in the context.
acquireLock(InvocationContext, Object) - Method in class org.infinispan.factories.EntryFactoryImpl
Attempts to lock an entry if the lock isn't already held in the current scope, and records the lock in the context.
acquireLock(Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
acquireLock(Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
acquireLock(Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
acquireLock(Object, boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Blocks until a lock is acquired.
acquireLock(String, boolean, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
acquireProcessingLock(boolean, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.DistributedSync
Acquires a processing lock.
acquireProcessingLock(boolean, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
acquireSync() - Method in interface org.infinispan.remoting.transport.DistributedSync
Acquires the sync.
acquireSync() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
activate() - Method in class org.infinispan.transaction.TransactionLog
 
ActivationInterceptor - Class in org.infinispan.interceptors
 
ActivationInterceptor() - Constructor for class org.infinispan.interceptors.ActivationInterceptor
 
activeStatusChanged(boolean) - Method in class org.infinispan.loaders.decorators.SingletonStore
Method called when the cache either becomes the coordinator or stops being the coordinator.
add(ReplicableCommand) - Method in class org.infinispan.remoting.ReplicationQueue
Adds a new method call.
add(E) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
add(E) - Method in class org.infinispan.util.ImmutableListCopy
 
add(E) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Adds the specified element to this set if it is not already present.
addAll(Collection<? extends E>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
addAll(Collection<? extends E>) - Method in class org.infinispan.util.ImmutableListCopy
 
addAll(int, Collection<? extends E>) - Method in class org.infinispan.util.ImmutableListCopy
 
addCacheLoader(CacheLoader, CacheLoaderConfig) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
addCacheLoaderConfig(CacheLoaderConfig) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
addChild(Fqn) - Method in interface org.infinispan.tree.Node
Adds a child node with the given Fqn under the current node.
addChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
addChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
addChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
addComponentDependencies(AbstractComponentRegistry.Component) - Method in class org.infinispan.factories.AbstractComponentRegistry
Adds component dependencies for a given component, by populating AbstractComponentRegistry.Component.injectionMethods.
addedEntries - Variable in class org.infinispan.util.Util.MapModifications
 
addEntry(InternalCacheEntry) - Method in class org.infinispan.loaders.bucket.Bucket
 
addErroneousAttribute(String) - Method in exception org.infinispan.config.ConfigurationException
 
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
addInterceptor(CommandInterceptor, int) - Method in interface org.infinispan.AdvancedCache
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 NUM_INTERCEPTORS - 1.
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.CacheDelegate
 
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.interceptors.InterceptorChain
Inserts the given interceptor at the specified position in the chain (o based indexing).
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Adds a custom interceptor to the interceptor chain, after an instance of the specified interceptor type.
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.CacheDelegate
 
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Adds a new interceptor in list after an interceptor of a given type.
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Adds a custom interceptor to the interceptor chain, before an instance of the specified interceptor type.
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.CacheDelegate
 
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Adds a new interceptor in list after an interceptor of a given type.
addListener(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
addListener(Object) - Method in class org.infinispan.CacheDelegate
 
addListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
addListener(Object) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
addListener(Object) - Method in interface org.infinispan.notifications.Listenable
Adds a listener to the component.
addModification(WriteCommand) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
addOperation(Operation) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
Address - Interface in org.infinispan.remoting.transport
// TODO: Manik: Document this!
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
addTransactionParticipants(List<Address>) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addTransactionParticipants(List<Address>) - Method in interface org.infinispan.context.impl.TxInvocationContext
Registers a new participant with the transaction.
AdvancedCache<K,V> - Interface in org.infinispan
An advanced interface that exposes additional methods not available on Cache.
AggregatingNotifyingFutureImpl - Class in org.infinispan.util.concurrent
For use with > 1 underlying network future
AggregatingNotifyingFutureImpl(Object, int) - Constructor for class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
appendIntereceptor(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Appends at the end.
applyModifications(List<? extends Modification>) - Method in class org.infinispan.loaders.AbstractCacheStore
 
applyModifications(List<? extends Modification>) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Perform the mods atomically by creating a worker and invoking them in TransactionRunner.run(com.sleepycat.collections.TransactionWorker).
applyModifications(List<? extends Modification>) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
applyModificationsSync(List<Modification>) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
applyOverrides(Configuration) - Method in class org.infinispan.config.Configuration
 
applyState(String, InputStream) - Method in interface org.infinispan.remoting.InboundInvocationHandler
Applies state onto a named cache.
applyState(String, InputStream) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
applyState(InputStream) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
applyState(InputStream) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
aquireGlobalLock(boolean, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Acquires RL on all locks agregated by this StripedLock, in the given timeout.
ArrayListExternalizer - Class in org.infinispan.marshall.jboss.externalizers
List externalizer dealing with ArrayList and LinkedList implementations.
ArrayListExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ArrayListExternalizer
 
asList() - Method in class org.infinispan.interceptors.InterceptorChain
Returns an unmofiable list with all the interceptors in sequence.
assertBatchingSupported(Configuration) - Method in class org.infinispan.batch.AutoBatchSupport
 
assertKeyNotNull(Object) - Method in class org.infinispan.util.AbstractMap
 
assertTransactionValid(TxInvocationContext) - Static method in class org.infinispan.context.impl.AbstractTxInvocationContext
Tests whether the caller is in a valid transaction.
assertTypeConstructable(Class, Class...) - Method in class org.infinispan.factories.AbstractComponentFactory
 
assertValid() - Method in class org.infinispan.config.Configuration
 
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_REPLICATION_QUEUE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_TRANSPORT_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
asyncProcessor - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
AsyncStore - Class in org.infinispan.loaders.decorators
The AsyncStore is a delegating CacheStore that extends AbstractDelegatingStore, overriding methods to that should not just delegate the operation to the underlying store.
AsyncStore(CacheStore, AsyncStoreConfig) - Constructor for class org.infinispan.loaders.decorators.AsyncStore
 
AsyncStoreConfig - Class in org.infinispan.loaders.decorators
Configuration for the async cache loader
AsyncStoreConfig() - Constructor for class org.infinispan.loaders.decorators.AsyncStoreConfig
 
AtomicHashMap<K,V> - Class in org.infinispan.atomic
Note that for replication to work properly, this class requires that all writes take place within the scope of an ongoing transaction or batch.
AtomicHashMap() - Constructor for class org.infinispan.atomic.AtomicHashMap
 
AtomicHashMap(boolean) - Constructor for class org.infinispan.atomic.AtomicHashMap
 
AtomicHashMapDelta - Class in org.infinispan.atomic
Changes that have occured on an AtomicHashMap
AtomicHashMapDelta() - Constructor for class org.infinispan.atomic.AtomicHashMapDelta
 
AtomicHashMapProxy<K,V> - Class in org.infinispan.atomic
A layer of indirection around an AtomicHashMap to provide reader consistency
AtomicHashMapProxy(Cache, Object, BatchContainer, InvocationContextContainer) - Constructor for class org.infinispan.atomic.AtomicHashMapProxy
 
AtomicMap<K,V> - Interface in org.infinispan.atomic
This is a special type of Map geared for use in Infinispan.
AtomicMapCache<K,V> - Interface in org.infinispan.atomic
This interface adds the getAtomicMap() method which allows users to get a hold of a map type where operations on its elements are all atomic.
attachGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.LockControlCommand
 
attachListener(FutureListener<T>) - Method in interface org.infinispan.util.concurrent.NotifyingFuture
Attaches a listener and returns the same future instance, to allow for 'building'.
attachListener(FutureListener<Object>) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
AutoBatchSupport - Class in org.infinispan.batch
Enables for automatic batching.
AutoBatchSupport() - Constructor for class org.infinispan.batch.AutoBatchSupport
 
AutoInstantiableFactory - Interface in org.infinispan.factories
Component factories that implement this interface can be instantiated automatically by component registries when looking up components.
available() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
await() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
await(long, TimeUnit) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
awaitForPushToFinish(Future, long, TimeUnit) - Method in class org.infinispan.loaders.decorators.SingletonStore
Method that waits for the in-memory to cache loader state to finish.
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 

B

BaseRpcCommand - Class in org.infinispan.commands.remote
Base class for RPC commands.
BaseRpcCommand(String) - Constructor for class org.infinispan.commands.remote.BaseRpcCommand
 
BaseRpcInterceptor - Class in org.infinispan.interceptors.base
Acts as a base for all RPC calls - subclassed by
BaseRpcInterceptor() - Constructor for class org.infinispan.interceptors.base.BaseRpcInterceptor
 
batchContainer - Variable in class org.infinispan.batch.AutoBatchSupport
 
BatchContainer - Class in org.infinispan.batch
A container for holding thread locals for batching, to be used with the Cache.startBatch() and Cache.endBatch(boolean) calls.
BatchContainer() - Constructor for class org.infinispan.batch.BatchContainer
 
batchContainer - Variable in class org.infinispan.CacheDelegate
 
BatchingInterceptor - Class in org.infinispan.interceptors
Interceptor that captures batched calls and attaches contexts.
BatchingInterceptor() - Constructor for class org.infinispan.interceptors.BatchingInterceptor
 
BatchModeTransactionManager - Class in org.infinispan.transaction.tm
Not really a transaction manager in the truest sense of the word.
BatchModeTransactionManager() - Constructor for class org.infinispan.transaction.tm.BatchModeTransactionManager
 
BdbjeCacheStore - Class in org.infinispan.loaders.bdbje
An Oracle SleepyCat JE implementation of a CacheStore.
BdbjeCacheStore() - Constructor for class org.infinispan.loaders.bdbje.BdbjeCacheStore
 
BdbjeCacheStoreConfig - Class in org.infinispan.loaders.bdbje
Configures BdbjeCacheStore.
BdbjeCacheStoreConfig() - Constructor for class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
BdbjeResourceFactory - Class in org.infinispan.loaders.bdbje
Factory that assembles objects specific to the SleepyCat JE API.
BdbjeResourceFactory(BdbjeCacheStoreConfig) - Constructor for class org.infinispan.loaders.bdbje.BdbjeResourceFactory
 
BeanUtils - Class in org.infinispan.util
Simple JavaBean manipulation helper methods
BeanUtils() - Constructor for class org.infinispan.util.BeanUtils
 
begin() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Starts a new transaction, and associate it with the calling thread.
begin() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Starts a new transaction, and associate it with the calling thread.
BidirectionalLinkedHashMap<K,V> - Class in org.infinispan.util
Similar to the JDK's LinkedHashMap except that this version makes use of the fact that entries are bidirectionally linked and can hence be nagigated either from the start or from the end.
BidirectionalLinkedHashMap(int, float) - Constructor for class org.infinispan.util.BidirectionalLinkedHashMap
Constructs an empty HashMap with the specified initial capacity and load factor.
BidirectionalLinkedHashMap(int, float, boolean) - Constructor for class org.infinispan.util.BidirectionalLinkedHashMap
Constructs an empty LinkedHashMap instance with the specified initial capacity, load factor and ordering mode.
BidirectionalLinkedHashMap(int) - Constructor for class org.infinispan.util.BidirectionalLinkedHashMap
Constructs an empty HashMap with the specified initial capacity and the default load factor (0.75).
BidirectionalLinkedHashMap() - Constructor for class org.infinispan.util.BidirectionalLinkedHashMap
Constructs an empty HashMap with the default initial capacity (16) and the default load factor (0.75).
BidirectionalLinkedHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.util.BidirectionalLinkedHashMap
Constructs a new HashMap with the same mappings as the specified Map.
BidirectionalMap<K,V> - Interface in org.infinispan.util
An extension of Map that returns ReversibleOrderedSets
block() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
blockUntilAcquired(long, TimeUnit) - Method in interface org.infinispan.remoting.transport.DistributedSync
Blocks until the start of a sync - either by the current RPCManager instance or a remote one - is received.
blockUntilAcquired(long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
blockUntilNoJoinsInProgress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
blockUntilReleased(long, TimeUnit) - Method in interface org.infinispan.remoting.transport.DistributedSync
Blocks until an ongoing sync ends.
blockUntilReleased(long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
BootstrapFactory - Class in org.infinispan.factories
Factory for setting up bootstrap components
BootstrapFactory(AdvancedCache, Configuration, ComponentRegistry) - Constructor for class org.infinispan.factories.BootstrapFactory
 
BoundedExecutors - Class in org.infinispan.util.concurrent
Similar to JDK Executors except that the factory methods here allow you to specify the size of the blocking queue that backs the executor.
BoundedExecutors() - Constructor for class org.infinispan.util.concurrent.BoundedExecutors
 
broadcastRpcCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to the entire cluster.
broadcastRpcCommand(ReplicableCommand, boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to the entire cluster.
broadcastRpcCommand(ReplicableCommand, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
broadcastRpcCommand(ReplicableCommand, boolean, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
broadcastRpcCommandInFuture(ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.broadcastRpcCommand(org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
broadcastRpcCommandInFuture(ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.broadcastRpcCommand(org.infinispan.commands.ReplicableCommand, boolean, boolean) except that the task is passed to the transport executor and a Future is returned.
broadcastRpcCommandInFuture(ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
broadcastRpcCommandInFuture(ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
Bucket - Class in org.infinispan.loaders.bucket
A bucket is where entries are stored.
Bucket() - Constructor for class org.infinispan.loaders.bucket.Bucket
 
BucketBasedCacheStore - Class in org.infinispan.loaders.bucket
Base class for cache store that want to use the 'buckets approach' for storing data.
BucketBasedCacheStore() - Constructor for class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
BucketExternalizer - Class in org.infinispan.marshall.jboss.externalizers
BucketExternalizer.
BucketExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.BucketExternalizer
 
buildClearCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildClearCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildClusteredGetCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
 
buildCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEvictCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildEvictCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetKeyValueCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildGetKeyValueCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInterceptorChain() - Method in class org.infinispan.factories.InterceptorChainFactory
 
buildInvalidateCommand(Object...) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateCommand(Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(Object...) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateFromL1Command(Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildLockControlCommand(Collection, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutKeyValueCommand(Object, Object, long, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutKeyValueCommand(Object, Object, long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map, long, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutMapCommand(Map, long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveCommand(Object, Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRemoveCommand(Object, Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplaceCommand(Object, Object, Object, long, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReplaceCommand(Object, Object, Object, long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplicateCommand(List<ReplicableCommand>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReplicateCommand(List<ReplicableCommand>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRollbackCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRollbackCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleRpcCommand(ReplicableCommand) - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleRpcCommand(ReplicableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSizeCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSizeCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferControlCommand(boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferControlCommand(boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
ByteBuffer - Class in org.infinispan.io
A byte buffer that exposes the internal byte array with minimal copying
ByteBuffer(byte[], int, int) - Constructor for class org.infinispan.io.ByteBuffer
 

C

Cache<K,V> - Interface in org.infinispan
The central interface of Infinispan.
CACHE_NAME_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
CacheComponent - Class in org.infinispan.jopr.infinispan
Component class for Caches within Infinispan
CacheComponent() - Constructor for class org.infinispan.jopr.infinispan.CacheComponent
 
CacheDelegate<K,V> - Class in org.infinispan
 
CacheDelegate(String) - Constructor for class org.infinispan.CacheDelegate
 
CacheDiscovery - Class in org.infinispan.jopr.infinispan
Discovery class for individual cache instances
CacheDiscovery() - Constructor for class org.infinispan.jopr.infinispan.CacheDiscovery
 
CacheEntry - Interface in org.infinispan.container.entries
An entry that is stored in the data container
CacheEntryActivated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is activated.
CacheEntryActivatedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryActivated.
CacheEntryCreated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is created.
CacheEntryCreatedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryCreated.
CacheEntryEvent - Interface in org.infinispan.notifications.cachelistener.event
Transactional events that additionally expose a key as such events pertain to a specific cache entry.
CacheEntryEvicted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is evicted.
CacheEntryEvictedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryEvicted.
CacheEntryInvalidated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is invalidated.
CacheEntryInvalidatedEvent - Interface in org.infinispan.notifications.cachelistener.event
Notifies a listener of an invalidation event
CacheEntryLoaded - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is loaded from a CacheLoader.
CacheEntryLoadedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryLoaded.
CacheEntryModified - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry has been modified.
CacheEntryModifiedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryModified
CacheEntryPassivated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is passivated.
CacheEntryPassivatedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryPassivated.
CacheEntryRemoved - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is removed from the cache.
CacheEntryRemovedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryRemoved.
CacheEntryVisited - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is visited.
CacheEntryVisitedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with CacheEntryVisited.
CacheException - Exception in org.infinispan
Thrown when operations on Cache fail unexpectedly.
CacheException() - Constructor for exception org.infinispan.CacheException
 
CacheException(Throwable) - Constructor for exception org.infinispan.CacheException
 
CacheException(String) - Constructor for exception org.infinispan.CacheException
 
CacheException(String, Throwable) - Constructor for exception org.infinispan.CacheException
 
CacheJmxRegistration - Class in org.infinispan.jmx
If Configuration.isExposeJmxStatistics() is true, then class will register all the MBeans from cache local's ConfigurationRegistry to the MBean server.
CacheJmxRegistration() - Constructor for class org.infinispan.jmx.CacheJmxRegistration
 
CacheLoader - Interface in org.infinispan.loaders
Responsible for loading cache data from an external source
cacheLoaderClassName - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
CacheLoaderConfig - Interface in org.infinispan.loaders
Configures individual cache loaders
CacheLoaderException - Exception in org.infinispan.loaders
An exception thrown by a CacheLoader implementation if there are problems reading from a loader.
CacheLoaderException() - Constructor for exception org.infinispan.loaders.CacheLoaderException
 
CacheLoaderException(String) - Constructor for exception org.infinispan.loaders.CacheLoaderException
 
CacheLoaderException(String, Throwable) - Constructor for exception org.infinispan.loaders.CacheLoaderException
 
CacheLoaderException(Throwable) - Constructor for exception org.infinispan.loaders.CacheLoaderException
 
CacheLoaderInterceptor - Class in org.infinispan.interceptors
 
CacheLoaderInterceptor() - Constructor for class org.infinispan.interceptors.CacheLoaderInterceptor
 
CacheLoaderManager - Interface in org.infinispan.loaders
The cache loader manager interface
CacheLoaderManagerConfig - Class in org.infinispan.config
Holds the configuration of the cache loader chain.
CacheLoaderManagerConfig() - Constructor for class org.infinispan.config.CacheLoaderManagerConfig
 
CacheLoaderManagerImpl - Class in org.infinispan.loaders
 
CacheLoaderManagerImpl() - Constructor for class org.infinispan.loaders.CacheLoaderManagerImpl
 
CacheManager - Interface in org.infinispan.manager
A CacheManager is the primary mechanism for retrieving a Cache instance, and is often used as a starting point to using the Cache.
CacheManagerJmxRegistration - Class in org.infinispan.jmx
Registers all the components from global component registry to the mbean server.
CacheManagerJmxRegistration() - Constructor for class org.infinispan.jmx.CacheManagerJmxRegistration
 
CacheManagerNotifier - Interface in org.infinispan.notifications.cachemanagerlistener
Notifications for the cache manager
CacheManagerNotifierImpl - Class in org.infinispan.notifications.cachemanagerlistener
Global, shared notifications on the cache manager.
CacheManagerNotifierImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
CacheMgmtInterceptor - Class in org.infinispan.interceptors
Captures cache management statistics
CacheMgmtInterceptor() - Constructor for class org.infinispan.interceptors.CacheMgmtInterceptor
 
cacheName - Variable in class org.infinispan.commands.remote.BaseRpcCommand
 
cacheName - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
CacheNotifier - Interface in org.infinispan.notifications.cachelistener
Public interface with all allowed notifications.
CacheNotifierImpl - Class in org.infinispan.notifications.cachelistener
Helper class that handles all notifications to registered listeners.
CacheNotifierImpl() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
CacheRpcCommand - Interface in org.infinispan.commands.remote
The RpcManager only replicates commands wrapped in a CacheRpcCommand.
cacheStarted(Event) - Method in class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
Cache started, check whether the cache is the coordinator and set the singleton store's active status.
CacheStarted - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is started.
CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStarted.
CacheStopped - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is stopped.
CacheStoppedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStopped.
CacheStore - Interface in org.infinispan.loaders
A specialization of the CacheLoader interface that can be written to.
CacheStoreConfig - Interface in org.infinispan.loaders
Defines config elements for all CacheStoreConfigs.
CacheStoreInterceptor - Class in org.infinispan.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.infinispan.interceptors.CacheStoreInterceptor
 
CacheStoreInterceptor.StoreModificationsBuilder - Class in org.infinispan.interceptors
 
CacheStoreInterceptor.StoreModificationsBuilder(boolean) - Constructor for class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
CacheTransaction - Interface in org.infinispan.transaction.xa
Defines the state a infinispan transaction should have.
calculateHashCode() - Method in class org.infinispan.tree.Fqn
Calculates a hash code by summing the hash code of all elements.
CallInterceptor - Class in org.infinispan.interceptors
Always at the end of the chain, directly in front of the cache.
CallInterceptor() - Constructor for class org.infinispan.interceptors.CallInterceptor
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
canExpire() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
canExpire() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
canExpire() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.MortalCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.TransientCacheValue
 
ChainingCacheStore - Class in org.infinispan.loaders.decorators
A chaining cache loader that allows us to configure > 1 cache loader.
ChainingCacheStore() - Constructor for class org.infinispan.loaders.decorators.ChainingCacheStore
 
checkStatisticsUsed() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
cleanup() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
clear(Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
clear() - Method in class org.infinispan.AbstractDelegatingCache
 
clear(Flag...) - Method in interface org.infinispan.AdvancedCache
 
clear() - Method in class org.infinispan.atomic.AtomicHashMap
 
clear() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
clear() - Method in class org.infinispan.CacheDelegate
 
clear(Flag...) - Method in class org.infinispan.CacheDelegate
 
clear() - Method in interface org.infinispan.container.DataContainer
Removes all entries in the container
clear() - Method in class org.infinispan.container.FIFODataContainer
 
clear() - Method in class org.infinispan.container.SimpleDataContainer
 
clear() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
clear() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Clears all entries in the store This implementation delegates to StoredContainer.clear()
clear() - Method in interface org.infinispan.loaders.CacheStore
Clears all entries in the store
clear() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
clear() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
clear() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
clear() - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
clear() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
clear() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
clear() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
clear() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Clear - Class in org.infinispan.loaders.modifications
Represents a CacheStore.clear() modification
Clear() - Constructor for class org.infinispan.loaders.modifications.Clear
 
clear() - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
removes all Infinispan buckets from the S3 bucket
clear() - Method in interface org.infinispan.loaders.s3.S3Bucket
removes all Infinispan buckets from the S3 bucket
clear() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.infinispan.util.FastCopyHashMap
 
clear() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Removes all of the elements from this set.
clearAsync(Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
clearAsync() - Method in class org.infinispan.AbstractDelegatingCache
 
clearAsync(Flag...) - Method in interface org.infinispan.AdvancedCache
 
clearAsync() - Method in interface org.infinispan.Cache
Asynchronous version of Map.clear().
clearAsync(Flag...) - Method in class org.infinispan.CacheDelegate
 
clearAsync() - Method in class org.infinispan.CacheDelegate
 
ClearCommand - Class in org.infinispan.commands.write
 
ClearCommand() - Constructor for class org.infinispan.commands.write.ClearCommand
 
ClearCommand(CacheNotifier) - Constructor for class org.infinispan.commands.write.ClearCommand
 
clearData() - Method in interface org.infinispan.tree.Node
Removes all mappings from the node's data map.
clearData(Flag...) - Method in interface org.infinispan.tree.Node
 
clearData() - Method in class org.infinispan.tree.NodeImpl
 
clearData(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
clearData(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes in a String represenation of the Fqn.
clearData(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
clearData(Fqn) - Method in interface org.infinispan.tree.TreeCache
Removes the keys and properties from a named node.
clearData(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
clearData(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
clearData(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
clearData(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
clearData(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
clearEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
clearLockSafe() - Method in class org.infinispan.loaders.file.FileCacheStore
 
clearLockSafe() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
clearLockSafe() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
clearLockSafe() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
clearLockSafe() - Method in class org.infinispan.loaders.s3.S3CacheStore
 
clearLookedUpEntries() - Method in interface org.infinispan.context.EntryLookup
Clears the collection of entries looked up
clearLookedUpEntries() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
clearLookedUpEntries() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clearLookedUpEntries() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
clearLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
clearLookedUpEntries() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
clearLookedUpEntries() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
ClearOperation<K,V> - Class in org.infinispan.atomic
 
ClearOperation() - Constructor for class org.infinispan.atomic.ClearOperation
 
clm - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
clone() - Method in class org.infinispan.config.AbstractConfigurationBean
 
clone() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
clone() - Method in interface org.infinispan.config.CloneableConfigurationComponent
 
clone() - Method in class org.infinispan.config.Configuration
 
clone() - Method in class org.infinispan.config.CustomInterceptorConfig
 
clone() - Method in class org.infinispan.config.GlobalConfiguration
 
clone() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
clone() - Method in class org.infinispan.config.RuntimeConfig
 
clone() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
clone() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
clone() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clone() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
clone() - Method in interface org.infinispan.context.InvocationContext
 
clone() - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
clone() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
clone() - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
clone() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
clone() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
clone() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
clone() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
clone() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
clone() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
clone() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns a shallow copy of this Map instance: the keys and values themselves are not cloned.
clone() - Method in class org.infinispan.util.FastCopyHashMap
 
clone() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
 
CloneableConfigurationComponent - Interface in org.infinispan.config
Interface for all configurable components
close() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
close() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
close() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
closeConnection() - Method in class org.infinispan.jopr.infinispan.ConnectionHelper
If necessary attempt to close the EMS connection, then set this.connection null.
closeInput(ObjectInput) - Static method in class org.infinispan.util.Util
 
closeStream(InputStream) - Static method in class org.infinispan.util.Util
 
ClusterCacheLoader - Class in org.infinispan.loaders.cluster
Cache loader that consults other members in the cluster for values.
ClusterCacheLoader() - Constructor for class org.infinispan.loaders.cluster.ClusterCacheLoader
 
ClusterCacheLoaderConfig - Class in org.infinispan.loaders.cluster
Configuration for ClusterCacheLoader.
ClusterCacheLoaderConfig() - Constructor for class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
ClusteredGetCommand - Class in org.infinispan.commands.remote
Issues a clustered get call, for use primarily by the org.infinispan.loader.cluster.ClusterCacheLoader.
ClusteredGetCommand() - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetCommand(Object, String) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetResponseValidityFilter - Class in org.infinispan.remoting.responses
A filter that tests the validity of ClusteredGetCommands.
ClusteredGetResponseValidityFilter(Collection<Address>) - Constructor for class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
codename - Static variable in class org.infinispan.Version
 
colorForRow(int) - Method in class org.infinispan.demo.InfinispanDemo.AlternateColorTable
Returns the appropriate background color for the given row.
COMMAND_ID - Static variable in class org.infinispan.commands.control.StateTransferControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.LockControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.ClusteredGetCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.MultipleRpcCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.SingleRpcCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.CommitCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.PrepareCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.RollbackCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ClearCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.InvalidateCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.InvalidateL1Command
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.PutKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.PutMapCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.RemoveCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ReplaceCommand
 
CommandAwareRpcDispatcher - Class in org.infinispan.remoting.transport.jgroups
A JGroups RPC dispatcher that knows how to deal with ReplicableCommands.
CommandAwareRpcDispatcher() - Constructor for class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
CommandAwareRpcDispatcher(Channel, JGroupsTransport, ExecutorService, InboundInvocationHandler, JGroupsDistSync, long) - Constructor for class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
CommandInterceptor - Class in org.infinispan.interceptors.base
This is the base class for all interceptors to extend, and implements the Visitor interface allowing it to intercept invocations on VisitableCommands.
CommandInterceptor() - Constructor for class org.infinispan.interceptors.base.CommandInterceptor
 
commandsFactory - Variable in class org.infinispan.CacheDelegate
 
CommandsFactory - Interface in org.infinispan.commands
 
CommandsFactoryImpl - Class in org.infinispan.commands
 
CommandsFactoryImpl() - Constructor for class org.infinispan.commands.CommandsFactoryImpl
 
commit() - Method in class org.infinispan.atomic.AtomicHashMap
 
commit() - Method in interface org.infinispan.atomic.DeltaAware
Indicate that all deltas collected to date has been extracted (via a call to DeltaAware.delta()) and can be discarded.
commit(DataContainer) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
commit(DataContainer) - Method in interface org.infinispan.container.entries.CacheEntry
Commits changes
commit(DataContainer) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
commit(GlobalTransaction) - Method in class org.infinispan.loaders.AbstractCacheStore
 
commit(GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Commits a transaction that has been previously prepared.

This implementation calls completeTransaction with an argument of true.

commit(GlobalTransaction) - Method in interface org.infinispan.loaders.CacheStore
Commits a transaction that has been previously prepared.
commit(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
commit(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
commit(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
commit(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
commit() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Commit the transaction associated with the calling thread.
commit() - Method in class org.infinispan.transaction.tm.DummyTransaction
Attempt to commit this transaction.
commit() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Attempt to commit this transaction.
commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
CommitCommand - Class in org.infinispan.commands.tx
// TODO: MANIK: Document this
CommitCommand(GlobalTransaction) - Constructor for class org.infinispan.commands.tx.CommitCommand
 
CommitCommand() - Constructor for class org.infinispan.commands.tx.CommitCommand
 
commitEntry(InvocationContext, CacheEntry) - Method in class org.infinispan.interceptors.DistLockingInterceptor
 
commitEntry(InvocationContext, CacheEntry) - Method in class org.infinispan.interceptors.LockingInterceptor
 
compact() - Method in class org.infinispan.AbstractDelegatingCache
 
compact() - Method in interface org.infinispan.Cache
Method that releases object references of cached objects held in the cache by serializing them to byte buffers.
compact() - Method in class org.infinispan.CacheDelegate
 
compact(boolean, boolean) - Method in class org.infinispan.marshall.MarshalledValue
Compacts the references held by this class to a single reference.
compare(Object, Object) - Method in class org.infinispan.loaders.jdbm.NaturalComparator
 
compare(Fqn, Fqn) - Method in class org.infinispan.tree.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.infinispan.tree.Fqn
Compares this Fqn to another using FqnComparator.
compareTo(byte[]) - Static method in class org.infinispan.Version
 
completeTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Looks up the SleepyCat transaction associated with the parameter tx.
ComponentName - Annotation Type in org.infinispan.factories.annotations
Mechanism for specifying the name of components to retrieve
componentRegistry - Variable in class org.infinispan.CacheDelegate
 
componentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
ComponentRegistry - Class in org.infinispan.factories
Named cache specific components
ComponentRegistry(String, Configuration, AdvancedCache, GlobalComponentRegistry) - Constructor for class org.infinispan.factories.ComponentRegistry
Creates an instance of the component registry.
ComponentsJmxRegistration - Class in org.infinispan.jmx
Registers a set of components on an MBean server.
ComponentsJmxRegistration(MBeanServer, Set<AbstractComponentRegistry.Component>, String) - Constructor for class org.infinispan.jmx.ComponentsJmxRegistration
C-tor.
ComponentStatus - Enum in org.infinispan.lifecycle
Different states a component may be in.
ConcurrentHashSet<E> - Class in org.infinispan.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.infinispan.util.concurrent.ConcurrentHashSet
 
ConcurrentHashSet(int) - Constructor for class org.infinispan.util.concurrent.ConcurrentHashSet
 
ConcurrentHashSet(int, float, int) - Constructor for class org.infinispan.util.concurrent.ConcurrentHashSet
Params passed in to the underlying CHM.
config - Variable in class org.infinispan.CacheDelegate
 
config - Variable in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
ConfigFilesConvertor - Class in org.infinispan.config.parsing
Class used for converting different configuration files to INFINISPAN format.
ConfigFilesConvertor() - Constructor for class org.infinispan.config.parsing.ConfigFilesConvertor
 
Configuration - Class in org.infinispan.config
Encapsulates the configuration of a Cache.
Configuration() - Constructor for class org.infinispan.config.Configuration
 
configuration - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
configuration - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
configuration - Variable in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
Configuration.CacheMode - Enum in org.infinispan.config
Cache replication mode.
CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CONFIGURATION_STRING - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CONFIGURATION_XML - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
ConfigurationException - Exception in org.infinispan.config
An exception that represents an error in the configuration.
ConfigurationException(Exception) - Constructor for exception org.infinispan.config.ConfigurationException
 
ConfigurationException(String) - Constructor for exception org.infinispan.config.ConfigurationException
 
ConfigurationException(String, String) - Constructor for exception org.infinispan.config.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.infinispan.config.ConfigurationException
 
ConfigurationRegistry - Interface in org.infinispan.config
A registry for Configurations.
configureGlobalJmxStatistics(Element, GlobalConfiguration) - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
 
connect(S3CacheStoreConfig, Marshaller) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
connect(S3CacheStoreConfig, Marshaller) - Method in interface org.infinispan.loaders.s3.S3Connection
 
ConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Defines the functionality a connection factory should implement.
ConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
 
ConnectionFactoryConfig - Class in org.infinispan.loaders.jdbc.connectionfactory
Contains configuration elements for a ConnectionFactory.
ConnectionFactoryConfig(String, String, String, String, String) - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
ConnectionFactoryConfig() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
ConnectionHelper - Class in org.infinispan.jopr.infinispan
Shared helper class to connect to a remote server
ConnectionHelper() - Constructor for class org.infinispan.jopr.infinispan.ConnectionHelper
 
ConsistentHash - Interface in org.infinispan.distribution
A consistent hash algorithm
ConstantObjectTable - Class in org.infinispan.marshall.jboss
Constant ObjectTable that marshalls constant instances regardless of whether these are generic objects such as UnsuccessfulResponse.INSTANCE, or home grown Externalizer implementations.
ConstantObjectTable(RemoteCommandFactory) - Constructor for class org.infinispan.marshall.jboss.ConstantObjectTable
 
construct(Class<T>) - Method in class org.infinispan.factories.AbstractComponentFactory
Constructs a component.
construct(Class<T>) - Method in class org.infinispan.factories.BootstrapFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.DataContainerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.DistributionManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.EmptyConstructorFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.EmptyConstructorNamedCacheFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.InterceptorChainFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.InternalCacheFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.LockManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.MarshallerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.NamedComponentFactory
 
construct(Class<T>, String) - Method in class org.infinispan.factories.NamedComponentFactory
Constructs a component.
construct(Class<T>, String) - Method in class org.infinispan.factories.NamedExecutorsFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.ReplicationQueueFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.ResponseGeneratorFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.RpcManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.StateTransferManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.TransactionManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.TransportFactory
 
contains(Object) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
contains(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
contains(Object) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns true if this set contains the specified element.
containsAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
containsInstance(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Checks whether the chain contains the supplied interceptor instance.
containsInterceptorType(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
 
containsKey(Object, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
containsKey(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
containsKey(Object, Flag...) - Method in interface org.infinispan.AdvancedCache
 
containsKey(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
containsKey(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
containsKey(Object) - Method in class org.infinispan.CacheDelegate
 
containsKey(Object, Flag...) - Method in class org.infinispan.CacheDelegate
 
containsKey(Object) - Method in interface org.infinispan.container.DataContainer
Tests whether an entry exists in the container
containsKey(Object) - Method in class org.infinispan.container.FIFODataContainer
 
containsKey(Object) - Method in class org.infinispan.container.SimpleDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
containsKey(Object) - Method in class org.infinispan.loaders.AbstractCacheLoader
This implementation delegates to CacheLoader.load(Object), to ensure that a response is returned only if the entry is not expired.
containsKey(Object) - Method in interface org.infinispan.loaders.CacheLoader
 
containsKey(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
containsKey(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
containsKey(Object) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns true if this map contains a mapping for the specified key.
containsKey(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
containsModificationType(Class<? extends ReplicableCommand>) - Method in class org.infinispan.commands.tx.PrepareCommand
 
containsPutForExternalRead - Variable in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
containsValue(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
containsValue(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
containsValue(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
containsValue(Object) - Method in class org.infinispan.CacheDelegate
 
containsValue(Object) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
context - Variable in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
contextFlags - Variable in class org.infinispan.context.impl.AbstractInvocationContext
 
copy() - Method in class org.infinispan.commands.tx.PrepareCommand
 
copy() - Method in class org.infinispan.io.ByteBuffer
 
copyBucket(String, String) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
copyBucket(String, String) - Method in interface org.infinispan.loaders.s3.S3Connection
 
copyForUpdate(DataContainer, boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
Makes internal copies of the entry for updates
copyForUpdate(DataContainer, boolean) - Method in class org.infinispan.container.entries.NullMarkerEntry
A no-op.
copyForUpdate(DataContainer, boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
copyForUpdate(DataContainer, boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
copyForWrite() - Method in class org.infinispan.atomic.AtomicHashMap
 
correctPrev(FIFODataContainer.LinkedEntry, FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Correct 'previous' links.
cr - Variable in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
create(Object, Object) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
create(Object, Object, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
create(Object, Object, long, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
create(Object, Object, long, long, long, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
createAndWire(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
 
createCache(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
This implementation clones the configuration passed in before using it.
createComparator() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
Returns a new comparator instance based on JdbmCacheStoreConfig.setComparatorClassName(String).
createCurrentTransaction(Environment) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
 
createDatabase(Environment, String) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
Open the database, creating it if it doesn't exist.
createDefaultCache(Configuration) - Method in class org.infinispan.factories.InternalCacheFactory
 
createEnvironment(File) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
Open the environment, creating it if it doesn't exist.
createInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
If we are in a tx scope this will return an TxInvocationContext.
createInvocationContext() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
createMarshalledValue(Object, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
createNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
Will create an NonTxInvocationContext with the NonTxInvocationContext.isOriginLocal() returning true.
createNonTxInvocationContext() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
createPreparableTransactionRunner(Environment) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
 
createPushStateTask() - Method in class org.infinispan.loaders.decorators.SingletonStore
Factory method for the creation of a Callable task in charge of pushing in-memory state to cache loader.
createRemoteInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
Returns an NonTxInvocationContext whose NonTxInvocationContext.isOriginLocal() flag will be true.
createRemoteInvocationContext() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
createRemoteTransaction(GlobalTransaction, WriteCommand[]) - Method in class org.infinispan.transaction.xa.TransactionTable
Creates and register a RemoteTransaction based on the supplied params.
createRemoteTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
Returns an RemoteTxInvocationContext.
createRemoteTxInvocationContext() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
createStoredClassCatalog(Database) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
 
createStoredMapViewOfDatabase(Database, StoredClassCatalog, Marshaller) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
create a StoredMap persisted by the database
createStoredSortedMapForKeyExpiry(Database, StoredClassCatalog, Marshaller) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
create a StoredMap persisted by the database
createTable(Connection) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
createTreeCache(Cache<K, V>) - Method in class org.infinispan.tree.TreeCacheFactory
Creates a TreeCache instance by taking in a Cache as a parameter
createTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
Returns a LocalTxInvocationContext.
createTxInvocationContext() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
createValue(Object) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
createValue(Object, long, long, long, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
currentRequestor() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
CustomInterceptorConfig - Class in org.infinispan.config
Holds information about the custom interceptors defined in the configuration file.
CustomInterceptorConfig(CommandInterceptor, boolean, boolean, int, String, String) - Constructor for class org.infinispan.config.CustomInterceptorConfig
Builds a custom interceptor configuration.
CustomInterceptorConfig(CommandInterceptor, boolean, boolean, int, Class<? extends CommandInterceptor>, Class<? extends CommandInterceptor>) - Constructor for class org.infinispan.config.CustomInterceptorConfig
Builds a custom interceptor configuration.
CustomInterceptorConfig(CommandInterceptor) - Constructor for class org.infinispan.config.CustomInterceptorConfig
Constructs an interceptor config based on the supplied interceptor instance.
CustomInterceptorsElementParser - Class in org.infinispan.config.parsing.element
Utility class for parsing 'buddy' element in the .xml configuration file.
CustomInterceptorsElementParser() - Constructor for class org.infinispan.config.parsing.element.CustomInterceptorsElementParser
 

D

DataCommand - Interface in org.infinispan.commands
Commands of this type manipulate data in the cache.
DataContainer - Interface in org.infinispan.container
The main internal data structure which stores entries
DataContainerFactory - Class in org.infinispan.factories
Constructs the data container
DataContainerFactory() - Constructor for class org.infinispan.factories.DataContainerFactory
 
dataSize() - Method in interface org.infinispan.tree.Node
 
dataSize(Flag...) - Method in interface org.infinispan.tree.Node
 
dataSize() - Method in class org.infinispan.tree.NodeImpl
 
dataSize(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
DataWriteCommand - Interface in org.infinispan.commands.write
Mixes features from DataCommand and WriteCommand
deactivate() - Method in class org.infinispan.transaction.TransactionLog
 
debug(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
debug(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
debug(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
debug(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
debug(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
debug(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
debug(Object) - Method in interface org.infinispan.util.logging.Log
 
debug(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
debug(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
debug(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
DEBUG_DEPENDENCIES - Static variable in class org.infinispan.factories.AbstractComponentRegistry
 
decodeVersion(short) - Static method in class org.infinispan.Version
 
decodeVersionForSerialization(short) - Static method in class org.infinispan.Version
Serialization only looks at major and minor, not micro or below.
DEFAULT_BATCH_SIZE - Static variable in class org.infinispan.loaders.jdbc.TableManipulation
 
DEFAULT_CACHE_NAME - Static variable in class org.infinispan.manager.DefaultCacheManager
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
DEFAULT_DOUBLING_SIZE - Static variable in class org.infinispan.io.ExposedByteArrayOutputStream
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
DEFAULT_FETCH_SIZE - Static variable in class org.infinispan.loaders.jdbc.TableManipulation
 
DEFAULT_LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.config.GlobalConfiguration
Default replication version, from Version.getVersionShort().
DefaultCacheManager - Class in org.infinispan.manager
A CacheManager is the primary mechanism for retrieving a Cache instance, and is often used as a starting point to using the Cache.
DefaultCacheManager() - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a default instance of the CacheManager, using configuration defaults.
DefaultCacheManager(boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a default instance of the CacheManager, using configuration defaults.
DefaultCacheManager(Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the default configuration passed in.
DefaultCacheManager(Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the default configuration passed in.
DefaultCacheManager(GlobalConfiguration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the global configuration passed in, and system defaults for the default named cache configuration.
DefaultCacheManager(GlobalConfiguration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the global configuration passed in, and system defaults for the default named cache configuration.
DefaultCacheManager(GlobalConfiguration, Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the global and default configurations passed in.
DefaultCacheManager(GlobalConfiguration, Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the global and default configurations passed in.
DefaultCacheManager(String) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the configuration file name passed in.
DefaultCacheManager(String, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the configuration file name passed in.
DefaultCacheManager(InputStream) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(InputStream, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
defaultClassLoader - Variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
DefaultConsistentHash - Class in org.infinispan.distribution
 
DefaultConsistentHash() - Constructor for class org.infinispan.distribution.DefaultConsistentHash
 
DefaultExecutorFactory - Class in org.infinispan.executors
Default executor factory that creates executors using the JDK Executors service.
DefaultExecutorFactory() - Constructor for class org.infinispan.executors.DefaultExecutorFactory
 
DefaultFactoryFor - Annotation Type in org.infinispan.factories.annotations
An annotation that is used internally, for defining a DEFAULT factory to be used when constructing components.
DefaultKey2StringMapper - Class in org.infinispan.loaders.jdbc.stringbased
Default implementation for Key2StringMapper.
DefaultKey2StringMapper() - Constructor for class org.infinispan.loaders.jdbc.stringbased.DefaultKey2StringMapper
 
DefaultResponseGenerator - Class in org.infinispan.remoting.responses
The default response generator for most cache modes
DefaultResponseGenerator() - Constructor for class org.infinispan.remoting.responses.DefaultResponseGenerator
 
DefaultScheduledExecutorFactory - Class in org.infinispan.executors
Creates scheduled executors using the JDK Executors service
DefaultScheduledExecutorFactory() - Constructor for class org.infinispan.executors.DefaultScheduledExecutorFactory
 
defaultSynchronous - Variable in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
defineCache(String, Configuration) - Method in interface org.infinispan.manager.CacheManager
Defines a named cache.
defineCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
Defines a named cache.
delistResource(XAResource, int) - Method in class org.infinispan.transaction.tm.DummyTransaction
Delist an XA resource from this transaction.
delta() - Method in class org.infinispan.atomic.AtomicHashMap
 
Delta - Interface in org.infinispan.atomic
Represents changes made to a DeltaAware implementation.
delta() - Method in interface org.infinispan.atomic.DeltaAware
Extracts changes made to implementations, in an efficient format that can easily and cheaply be serialized and deserialized.
DeltaAware - Interface in org.infinispan.atomic
This interface allows the extraction of deltas.
DeltaAwareExternalizer - Class in org.infinispan.marshall.jboss.externalizers
DeltaAwareExternalizer.
DeltaAwareExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.DeltaAwareExternalizer
 
deserialize(byte[]) - Method in class org.infinispan.loaders.jdbm.JdbmSerializer
 
deserialize() - Method in class org.infinispan.marshall.MarshalledValue
 
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
destroyBucket(String) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
destroyBucket(String) - Method in interface org.infinispan.loaders.s3.S3Connection
 
detectScope(Class) - Static method in class org.infinispan.factories.scopes.ScopeDetector
 
disconnect() - Method in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
disconnect() - Method in interface org.infinispan.loaders.s3.S3Connection
 
discoverResources(ResourceDiscoveryContext<InfinispanComponent>) - Method in class org.infinispan.jopr.infinispan.CacheDiscovery
Run the discovery
discoverResources(ResourceDiscoveryContext<InfinispanComponent>) - Method in class org.infinispan.jopr.infinispan.InfinispanDiscovery
Run the discovery
DistLockingInterceptor - Class in org.infinispan.interceptors
A subclass of the locking interceptor that is able to differentiate committing changes on a ReadCommittedEntry for storage in the main cache or in L1, used by DIST
DistLockingInterceptor() - Constructor for class org.infinispan.interceptors.DistLockingInterceptor
 
DistributedSync - Interface in org.infinispan.remoting.transport
This is an abstraction of a cluster-wide synchronization.
DistributedSync.SyncResponse - Enum in org.infinispan.remoting.transport
 
DistributionInterceptor - Class in org.infinispan.interceptors
The interceptor that handles distribution of entries across a cluster, as well as transparent lookup
DistributionInterceptor() - Constructor for class org.infinispan.interceptors.DistributionInterceptor
 
DistributionManager - Interface in org.infinispan.distribution
A component that manages the distribution of elements across a cache cluster
DistributionManagerFactory - Class in org.infinispan.factories
 
DistributionManagerFactory() - Constructor for class org.infinispan.factories.DistributionManagerFactory
 
DistributionManagerImpl - Class in org.infinispan.distribution
The default distribution manager implementation
DistributionManagerImpl() - Constructor for class org.infinispan.distribution.DistributionManagerImpl
 
DistributionManagerImpl.ViewChangeListener - Class in org.infinispan.distribution
 
DistributionManagerImpl.ViewChangeListener() - Constructor for class org.infinispan.distribution.DistributionManagerImpl.ViewChangeListener
 
DistributionResponseGenerator - Class in org.infinispan.remoting.responses
A response generator for the DIST cache mode
DistributionResponseGenerator() - Constructor for class org.infinispan.remoting.responses.DistributionResponseGenerator
 
DistTxInterceptor - Class in org.infinispan.interceptors
A special form of the TxInterceptor that is aware of distribution and consistent hashing, and as such only replays methods during a remote prepare that are targeted to this specific cache instance.
DistTxInterceptor() - Constructor for class org.infinispan.interceptors.DistTxInterceptor
 
doAfterCall(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Callback that is invoked after every handleXXX() method defined above.
doBeforeCall(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
doConnectionFactoryInitialization(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
Keeps a reference to the connection factory for further use.
doConnectionFactoryInitialization(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
Keeps a reference to the connection factory for further use.
doWork() - Method in class org.infinispan.loaders.bdbje.ModificationsTransactionWorker
This implementation iterates through a list of work represented by Modification objects and executes it against the CacheStore.

Current commands supported are: STORE CLEAR REMOVE PURGE_EXPIRED

dropTable(Connection) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
DummyBaseTransactionManager - Class in org.infinispan.transaction.tm
 
DummyBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
DummyTransaction - Class in org.infinispan.transaction.tm
 
DummyTransaction(DummyBaseTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyTransaction
 
DummyTransactionManager - Class in org.infinispan.transaction.tm
Simple transaction manager implementation that maintains transaction state in memory only.
DummyTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyTransactionManager
 
DummyTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Returns an instance of DummyTransactionManager.
DummyTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
DummyUserTransaction - Class in org.infinispan.transaction.tm
 
DummyUserTransaction(DummyTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyUserTransaction
 
DummyXid - Class in org.infinispan.transaction.tm
Implementation of Xid.
DummyXid() - Constructor for class org.infinispan.transaction.tm.DummyXid
 
DuplicateCacheNameException - Exception in org.infinispan.config
Thrown if a duplicate named cache is detected
DuplicateCacheNameException(Exception) - Constructor for exception org.infinispan.config.DuplicateCacheNameException
 
DuplicateCacheNameException(String) - Constructor for exception org.infinispan.config.DuplicateCacheNameException
 
DuplicateCacheNameException(String, String) - Constructor for exception org.infinispan.config.DuplicateCacheNameException
 
DuplicateCacheNameException(String, Throwable) - Constructor for exception org.infinispan.config.DuplicateCacheNameException
 
duplicateCollection(Collection<E>) - Static method in class org.infinispan.util.ObjectDuplicator
 
duplicateMap(Map<K, V>) - Static method in class org.infinispan.util.ObjectDuplicator
 
duplicateReversibleOrderedSet(ReversibleOrderedSet<E>) - Static method in class org.infinispan.util.ObjectDuplicator
 
duplicateSet(Set<E>) - Static method in class org.infinispan.util.ObjectDuplicator
 
Dynamic - Annotation Type in org.infinispan.config
Annotation that marks fields in Configuration as being modifiable even after the cache has started.

E

elements - Variable in class org.infinispan.tree.Fqn
 
EMPTY_PROPERTIES - Static variable in class org.infinispan.config.AbstractConfigurationBean
 
emptyBidirectionalMap() - Static method in class org.infinispan.util.InfinispanCollections
 
EmptyConstructorFactory - Class in org.infinispan.factories
Factory for building global-scope components which have default empty constructors
EmptyConstructorFactory() - Constructor for class org.infinispan.factories.EmptyConstructorFactory
 
EmptyConstructorNamedCacheFactory - Class in org.infinispan.factories
Simple factory that just uses reflection and an empty constructor of the component type.
EmptyConstructorNamedCacheFactory() - Constructor for class org.infinispan.factories.EmptyConstructorNamedCacheFactory
 
emptyReversibleOrderedSet() - Static method in class org.infinispan.util.InfinispanCollections
 
encodeVersion(int, int, int) - Static method in class org.infinispan.Version
 
end(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
endAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
endBatch(boolean) - Method in class org.infinispan.AbstractDelegatingCache
 
endBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
endBatch(boolean, boolean) - Method in class org.infinispan.batch.BatchContainer
 
endBatch(boolean) - Method in interface org.infinispan.Cache
Completes a batch if one has been started using Cache.startBatch().
endBatch(boolean) - Method in class org.infinispan.CacheDelegate
 
enlist(InvocationContext) - Method in class org.infinispan.interceptors.TxInterceptor
 
enlistResource(XAResource) - Method in class org.infinispan.transaction.tm.DummyTransaction
Enlist an XA resource with this transaction.
EntryFactory - Interface in org.infinispan.factories
// TODO: MANIK: Document this
EntryFactoryImpl - Class in org.infinispan.factories
 
EntryFactoryImpl() - Constructor for class org.infinispan.factories.EntryFactoryImpl
 
EntryLookup - Interface in org.infinispan.context
Interface that can look up MVCC wrapped entries.
entrySet() - Method in class org.infinispan.AbstractDelegatingCache
 
entrySet() - Method in class org.infinispan.atomic.AtomicHashMap
 
entrySet() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
entrySet() - Method in class org.infinispan.CacheDelegate
 
entrySet - Variable in class org.infinispan.util.AbstractMap
 
entrySet() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
 
entrySet() - Method in interface org.infinispan.util.BidirectionalMap
 
entrySet() - Method in class org.infinispan.util.FastCopyHashMap
 
eq(Object, Object) - Static method in class org.infinispan.util.AbstractMap
 
equals(Object) - Method in class org.infinispan.commands.LockControlCommand
 
equals(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
equals(Object) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
equals(Object) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
equals(Object) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
equals(Object) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
equals(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
equals(Object) - Method in class org.infinispan.commands.write.PutMapCommand
 
equals(Object) - Method in class org.infinispan.commands.write.RemoveCommand
 
equals(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
equals(Object) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
equals(Object) - Method in class org.infinispan.config.Configuration
 
equals(Object) - Method in class org.infinispan.config.CustomInterceptorConfig
 
equals(Object) - Method in class org.infinispan.config.GlobalConfiguration
 
equals(Object) - Method in class org.infinispan.config.PluggableConfigurationComponent
 
equals(Object) - Method in class org.infinispan.config.RuntimeConfig
 
equals(Object) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
equals(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
equals(Object) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
equals(Object) - Method in class org.infinispan.loaders.modifications.Remove
 
equals(Object) - Method in class org.infinispan.loaders.modifications.Store
 
equals(Object) - Method in class org.infinispan.marshall.MarshalledValue
 
equals(Object) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
equals(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
equals(Object) - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
equals(Object) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
equals(Object) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
equals(Object) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
equals(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
equals(Object) - Method in class org.infinispan.tree.Fqn
Returns true if obj is a Fqn with the same elements.
equals(Object) - Method in class org.infinispan.tree.NodeImpl
 
equals(Object) - Method in class org.infinispan.tree.NodeKey
 
equals(Object) - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
equals(Object) - Method in class org.infinispan.util.SimpleImmutableEntry
 
equals(Object) - Method in class org.infinispan.util.Util.MapModifications
 
equalsExcludingProperties(Object) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
error(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
error(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
error(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
error(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
error(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
error(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
error(Object) - Method in interface org.infinispan.util.logging.Log
 
error(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
error(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
error(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
escapeBackslashes(String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Escapes backslashes ('\') with additional backslashes in a given String, returning a new, escaped String.
Event - Interface in org.infinispan.notifications.cachelistener.event
An interface that defines common characteristics of events
Event - Interface in org.infinispan.notifications.cachemanagerlistener.event
Common characteristics of events that occur on a cache manager
Event.Type - Enum in org.infinispan.notifications.cachelistener.event
 
Event.Type - Enum in org.infinispan.notifications.cachemanagerlistener.event
 
EventImpl - Class in org.infinispan.notifications.cachelistener.event
Basic implementation of an event that covers all event types.
EventImpl() - Constructor for class org.infinispan.notifications.cachelistener.event.EventImpl
 
EventImpl - Class in org.infinispan.notifications.cachemanagerlistener.event
Implementation of cache manager events
EventImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
EventImpl(String, CacheManager, Event.Type, List<Address>, Address) - Constructor for class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
evict(K) - Method in class org.infinispan.AbstractDelegatingCache
 
evict(K) - Method in interface org.infinispan.Cache
Evicts an entry from the memory of the cache.
evict(K) - Method in class org.infinispan.CacheDelegate
 
EvictCommand - Class in org.infinispan.commands.write
 
EvictCommand(Object, CacheNotifier) - Constructor for class org.infinispan.commands.write.EvictCommand
 
EVICTION_SCHEDULED_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
EvictionManager - Interface in org.infinispan.eviction
Central component that deals with eviction of cache entries.
EvictionManagerImpl - Class in org.infinispan.eviction
 
EvictionManagerImpl() - Constructor for class org.infinispan.eviction.EvictionManagerImpl
 
EvictionStrategy - Enum in org.infinispan.eviction
Supported eviction strategies
ExceptionResponse - Class in org.infinispan.remoting.responses
A response that encapsulates an exception
ExceptionResponse() - Constructor for class org.infinispan.remoting.responses.ExceptionResponse
 
ExceptionResponse(Exception) - Constructor for class org.infinispan.remoting.responses.ExceptionResponse
 
ExceptionResponseExternalizer - Class in org.infinispan.marshall.jboss.externalizers
Externalizes an ExceptionResponse
ExceptionResponseExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ExceptionResponseExternalizer
 
execute(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
executeCommand(CacheRpcCommand, Message) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
ExecutorFactory - Interface in org.infinispan.executors
Used to configure and create executors
existModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
exists(String) - Method in interface org.infinispan.tree.TreeCache
Tests if an Fqn exists.
exists(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
exists(Fqn) - Method in interface org.infinispan.tree.TreeCache
Tests if an Fqn exists.
exists(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
exists(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
exists(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
exists(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
exists(Fqn) - Method in class org.infinispan.tree.TreeStructureSupport
 
existsAttribute(String) - Method in class org.infinispan.config.parsing.XmlParserBase
 
ExposedByteArrayOutputStream - Class in org.infinispan.io
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
ExtendedResponse - Class in org.infinispan.remoting.responses
A response with extended information
ExtendedResponse(Response, boolean) - Constructor for class org.infinispan.remoting.responses.ExtendedResponse
 
ExtendedResponseExternalizer - Class in org.infinispan.marshall.jboss.externalizers
ExtendedResponseExternalizer.
ExtendedResponseExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ExtendedResponseExternalizer
 
Externalizer - Interface in org.infinispan.marshall.jboss
Extended interface that extends capabilities of writing predefined objects with the possibility of reading them.
extractProperties(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 

F

FastCopyHashMap<K,V> - Class in org.infinispan.util
A HashMap that is optimized for fast shallow copies.
FastCopyHashMap(int, float) - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap(int) - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap() - Constructor for class org.infinispan.util.FastCopyHashMap
 
fatal(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
fatal(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
fatal(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
fatal(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
fatal(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
fatal(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
fatal(Object) - Method in interface org.infinispan.util.logging.Log
 
fatal(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
fatal(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
fatal(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
FIFODataContainer - Class in org.infinispan.container
A container that maintains order of entries based on when they were placed in the container.
FIFODataContainer() - Constructor for class org.infinispan.container.FIFODataContainer
 
FIFODataContainer.KeyIterator - Class in org.infinispan.container
 
FIFODataContainer.KeyIterator() - Constructor for class org.infinispan.container.FIFODataContainer.KeyIterator
 
FIFODataContainer.KeySet - Class in org.infinispan.container
 
FIFODataContainer.KeySet() - Constructor for class org.infinispan.container.FIFODataContainer.KeySet
 
FIFODataContainer.LinkedIterator - Class in org.infinispan.container
 
FIFODataContainer.LinkedIterator() - Constructor for class org.infinispan.container.FIFODataContainer.LinkedIterator
 
FIFODataContainer.ValueIterator - Class in org.infinispan.container
 
FIFODataContainer.ValueIterator() - Constructor for class org.infinispan.container.FIFODataContainer.ValueIterator
 
FileCacheStore - Class in org.infinispan.loaders.file
A filesystem-based implementation of a BucketBasedCacheStore.
FileCacheStore() - Constructor for class org.infinispan.loaders.file.FileCacheStore
 
FileCacheStoreConfig - Class in org.infinispan.loaders.file
Configures FileCacheStore.
FileCacheStoreConfig() - Constructor for class org.infinispan.loaders.file.FileCacheStoreConfig
 
FileLookup - Class in org.infinispan.util
Holds the logic of looking up a file, in the following sequence: try to load it with the curent thread's context ClassLoader if fails, the system ClassLoader if fails, try to load it as a file from the disck
FileLookup() - Constructor for class org.infinispan.util.FileLookup
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
finishObjectInput(ObjectInput) - Method in interface org.infinispan.marshall.Marshaller
Finish using the given ObjectInput.
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.marshall.Marshaller
Finish using the given ObjectOutput.
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
Flag - Enum in org.infinispan.context
Available flags, which may be set on a per-invocation basis.
FlagContainer - Interface in org.infinispan.context
Interface that defines access to and manipulation of Flag.
flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
flags - Variable in class org.infinispan.context.impl.AbstractInvocationContext
 
flush() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
flush() - Method in class org.infinispan.remoting.ReplicationQueue
Flushes existing method calls.
flushAndCloseOutput(ObjectOutput) - Static method in class org.infinispan.util.Util
 
flushAndCloseStream(OutputStream) - Static method in class org.infinispan.util.Util
 
forget(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
Fqn - Class in org.infinispan.tree
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 in a TreeCache.
Fqn() - Constructor for class org.infinispan.tree.Fqn
Public to satisfy Externalization.
FqnComparator - Class in org.infinispan.tree
Compares the order of two FQN.
FqnComparator() - Constructor for class org.infinispan.tree.FqnComparator
 
fromElements(Object...) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the array of elements passed in.
fromExternalStream(ObjectInput) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn read from an object input stream, typically written to using Fqn.writeExternal(java.io.ObjectOutput).
fromList(List) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the list of elements passed in.
fromList(List, boolean) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the list of elements passed in.
fromRelativeElements(Fqn, Object...) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the array of elements passed in, relative to the base Fqn.
fromRelativeFqn(Fqn, Fqn) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the absolute Fqn of the relative Fqn passed in.
fromRelativeList(Fqn, List) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the List of elements passed in, relative to the base Fqn.
fromStream(byte, Object[]) - Method in class org.infinispan.commands.RemoteCommandFactory
Creates an un-initialized command.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Writes contents of the stream to the store. This implementation reads the number of entries to load from the stream, then begins a transaction.
fromStream(ObjectInput) - Method in interface org.infinispan.loaders.CacheStore
Writes contents of the stream to the store.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Reads from a stream the number of entries (long) then the entries themselves.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.s3.S3CacheStore
 
fromString(String) - Static method in class org.infinispan.tree.Fqn
Returns a new Fqn from a string, where the elements are deliminated by one or more separator (Fqn.SEPARATOR) characters.

Example use:
futureDone(Future<T>) - Method in interface org.infinispan.util.concurrent.FutureListener
 
FutureListener<T> - Interface in org.infinispan.util.concurrent
A listener that is called back when a future is done.

G

generateState(String, OutputStream) - Method in interface org.infinispan.remoting.InboundInvocationHandler
Generates state from a named cache.
generateState(String, OutputStream) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
generateState(OutputStream) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
generateState(OutputStream) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
GenericTransactionManagerLookup - Class in org.infinispan.transaction.lookup
A transaction manager lookup class that attempts to locate a TransactionManager.
GenericTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
get(Object, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
get(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
get(Object, Flag...) - Method in interface org.infinispan.AdvancedCache
 
get(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
get(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
get(Object) - Method in class org.infinispan.CacheDelegate
 
get(Object, Flag...) - Method in class org.infinispan.CacheDelegate
 
get(Object) - Method in interface org.infinispan.container.DataContainer
Retrieves a cached entry
get(Object) - Method in class org.infinispan.container.FIFODataContainer
 
get(Object) - Method in class org.infinispan.container.LRUDataContainer
 
get(Object) - Method in class org.infinispan.container.SimpleDataContainer
 
get(Object) - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
get(Object) - Method in class org.infinispan.container.SpinLockBasedLRUDataContainer
 
get(String) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
get(String) - Method in interface org.infinispan.loaders.s3.S3Bucket
 
get() - Method in class org.infinispan.marshall.MarshalledValue
Returns the 'cached' instance.
get(int) - Method in class org.infinispan.tree.Fqn
 
get(K) - Method in interface org.infinispan.tree.Node
Returns the value to which this node maps the specified key.
get(K, Flag...) - Method in interface org.infinispan.tree.Node
 
get(K) - Method in class org.infinispan.tree.NodeImpl
 
get(K, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
get(Fqn, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that allows for direct access to the data in a Node.
get(Fqn, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
get(String, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
get(String, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
get(Fqn, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(Fqn, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(String, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(String, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(Object) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
get() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
get(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
get(int) - Method in class org.infinispan.util.ImmutableListCopy
 
getActivations() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
getAddress() - Method in interface org.infinispan.manager.CacheManager
 
getAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getAddress() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getAddress() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's network address
getAddress() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getAdvancedCache() - Method in class org.infinispan.AbstractDelegatingCache
 
getAdvancedCache() - Method in interface org.infinispan.Cache
 
getAdvancedCache() - Method in class org.infinispan.CacheDelegate
 
getAfter() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getAllElements(String, String, Element) - Method in class org.infinispan.config.parsing.XmlParserBase
Convenience method for retrieving all child elements bearing the same element name
getAllElementsInCoreNS(String, Element) - Method in class org.infinispan.config.parsing.XmlParserBase
Convenience method for retrieving all child elements bearing the same element name, in the core namespace
getAllMethods(Class, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllowedMethodAnnotations() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getAllowedMethodAnnotations() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getAllowedMethodAnnotations() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getAncestor(int) - Method in class org.infinispan.tree.Fqn
Obtains an ancestor of the current Fqn.
getAnnotation(Class, Class<T>) - Static method in class org.infinispan.util.ReflectionUtil
Inspects the class passed in for the class level annotation specified.
getAsInputStreamFromClassLoader(String) - Method in class org.infinispan.util.FileLookup
 
getAsyncCacheListenerExecutor() - Method in class org.infinispan.config.RuntimeConfig
This is only relevant if the async cache listener executor has been set using RuntimeConfig.setAsyncCacheListenerExecutor(java.util.concurrent.ExecutorService).
getAsyncListenerExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncListenerExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncSerializationExecutor() - Method in class org.infinispan.config.RuntimeConfig
This is only relevant if the async cache replication executor has been set using RuntimeConfig.setAsyncSerializationExecutor(ExecutorService).
getAsyncSerializationExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncSerializationExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getAsyncStoreConfig() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getAtomicMap(K) - Method in interface org.infinispan.atomic.AtomicMapCache
Returns an atomic map.
getAtomicMap(K) - Method in class org.infinispan.CacheDelegate
 
getAttribute(String) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributeValue(Element, String, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Retrieves the value of a given attribute for the first encountered instance of a tag in an element.
getAttributeValue(Element, String) - Method in class org.infinispan.config.parsing.XmlParserBase
Beside querying the element for its attribute value, it will look into the value, if any, and replace the jboss properties(e.g.
getAvailability() - Method in class org.infinispan.jopr.infinispan.CacheComponent
Return availability of this resource
getAvailability() - Method in class org.infinispan.jopr.infinispan.InfinispanComponent
Return availability of this resource.
getAverageReadTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAverageWriteTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAwsAccessKey() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getAwsSecretKey() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getBatchContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getBatchContainer() - Method in interface org.infinispan.AdvancedCache
 
getBatchContainer() - Method in class org.infinispan.CacheDelegate
 
getBatchSize() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getBatchSize() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
getBatchSize() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getBatchSize() - Method in class org.infinispan.loaders.jdbc.TableManipulation
When doing repetitive DB inserts (e.g.
getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
 
getBefore() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getBoolean(String) - Method in class org.infinispan.config.parsing.XmlParserBase
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.util.TypedProperties
 
getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyXid
 
getBucket() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getBucketName() - Method in class org.infinispan.loaders.bucket.Bucket
 
getBuf() - Method in class org.infinispan.io.ByteBuffer
 
getCache() - Method in interface org.infinispan.manager.CacheManager
Retrieves the default cache associated with this cache manager.
getCache(String) - Method in interface org.infinispan.manager.CacheManager
Retrieves a named cache from the system.
getCache() - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves the default cache associated with this cache manager.
getCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves a named cache from the system.
getCache() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getCache() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getCache() - Method in interface org.infinispan.tree.TreeCache
 
getCache() - Method in class org.infinispan.tree.TreeCacheImpl
 
getCacheDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getCacheLoader() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
getCacheLoader() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
getCacheLoaderClassName() - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
getCacheLoaderClassName() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getCacheLoaderClassName() - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
getCacheLoaderClassName() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
getCacheLoaderConfigs() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
getCacheLoaderLoads() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaderManagerConfig() - Method in class org.infinispan.config.Configuration
 
getCacheLoaderMisses() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaderStores() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
getCacheManager() - Method in class org.infinispan.AbstractDelegatingCache
 
getCacheManager() - Method in interface org.infinispan.Cache
Retrieves the cache manager responsible for creating this cache instance.
getCacheManager() - Method in class org.infinispan.CacheDelegate
 
getCacheManager() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getCacheManager() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getCacheMode() - Method in class org.infinispan.config.Configuration
 
getCacheModeString() - Method in class org.infinispan.config.Configuration
 
getCacheName() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
getCacheName() - Method in interface org.infinispan.commands.remote.CacheRpcCommand
 
getCacheName() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getCacheName() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getCacheName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.CacheStartedEvent
 
getCacheName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.CacheStoppedEvent
 
getCacheName() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getCacheStore() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
getCacheStore() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
getCatalogDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getChangeLogSize() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getChild(Fqn) - Method in interface org.infinispan.tree.Node
Returns the child node
getChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
getChild(Object) - Method in interface org.infinispan.tree.Node
 
getChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
getChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
getChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
getChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChildren() - Method in interface org.infinispan.tree.Node
Returns an immutable set of children nodes.
getChildren(Flag...) - Method in interface org.infinispan.tree.Node
 
getChildren() - Method in class org.infinispan.tree.NodeImpl
 
getChildren(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChildrenNames() - Method in interface org.infinispan.tree.Node
Returns an immutable set of children node names.
getChildrenNames(Flag...) - Method in interface org.infinispan.tree.Node
 
getChildrenNames() - Method in class org.infinispan.tree.NodeImpl
 
getChildrenNames(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getClassForName(String) - Static method in class org.infinispan.jmx.ResourceDMBean
 
getClusteredDefault() - Static method in class org.infinispan.config.GlobalConfiguration
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
getClusterName() - Method in class org.infinispan.config.GlobalConfiguration
 
getClusterName() - Method in interface org.infinispan.manager.CacheManager
 
getClusterName() - Method in class org.infinispan.manager.DefaultCacheManager
 
getColumnCount() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getColumnCount() - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getColumnName(int) - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getColumnName(int) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getCommand() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommandId() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getCommandId() - Method in class org.infinispan.commands.LockControlCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.read.SizeCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommandId() - Method in interface org.infinispan.commands.ReplicableCommand
Used by marshallers to convert this command into an id for streaming.
getCommandId() - Method in class org.infinispan.commands.tx.CommitCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.RollbackCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ClearCommand
 
getCommandId() - Method in class org.infinispan.commands.write.EvictCommand
 
getCommandId() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getCommandId() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
getCommandId() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.write.PutMapCommand
 
getCommandId() - Method in class org.infinispan.commands.write.RemoveCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getCommands() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getCommandToReplay(VisitableCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
Only replays modifications that are
getCommandToReplay(VisitableCommand) - Method in class org.infinispan.interceptors.TxInterceptor
Designed to be overridden.
getCommits() - Method in class org.infinispan.interceptors.TxInterceptor
 
getComparatorClassName() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
Returns comparatorClassName.
getComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component of a specified type from the registry, or null if it cannot be found.
getComponent(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getComponent(Class<T>, String) - Method in class org.infinispan.factories.ComponentRegistry
 
getComponentRegistry() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getComponentRegistry() - Method in interface org.infinispan.AdvancedCache
 
getComponentRegistry() - Method in class org.infinispan.CacheDelegate
 
getConcurrencyLevel() - Method in class org.infinispan.config.Configuration
 
getConcurrencyLevel() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getConfiguration() - Method in class org.infinispan.AbstractDelegatingCache
 
getConfiguration() - Method in interface org.infinispan.Cache
 
getConfiguration() - Method in class org.infinispan.CacheDelegate
 
getConfiguration(String) - Method in interface org.infinispan.config.ConfigurationRegistry
Gets a clone of the Configuration registered under the given name.
getConfiguration() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the configuration component.
getConfigurationClass() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
getConfigurationClass() - Method in interface org.infinispan.loaders.CacheLoader
 
getConfigurationClass() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
getConfigurationClass() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.file.FileCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.s3.S3CacheStore
 
getConfigurationNames() - Method in interface org.infinispan.config.ConfigurationRegistry
Gets the names of all registered configurations.
getConnection() - Method in class org.infinispan.jopr.infinispan.InfinispanComponent
Helper to obtain a connection
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Fetches a connection from the factory.
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getConnection() - Method in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
getConnection() - Method in interface org.infinispan.loaders.s3.S3Connection
 
getConnectionFactory() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getConnectionFactory(String) - Static method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Constructs a ConnectionFactory based on the supplied class name.
getConnectionFactory() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getConnectionFactory() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getConnectionFactoryClass() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionFactoryConfig() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
getConnectionFactoryConfig() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
getConnectionFactoryConfig() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getConnectionUrl() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionUrl() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getConsistentHashClass() - Method in class org.infinispan.config.Configuration
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
getCreated() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getCreated() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
getCreated() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getCreatedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCurrentStateTransferSource() - Method in interface org.infinispan.remoting.rpc.RpcManager
If RpcManager.retrieveState(String, long) has been invoked and hasn't yet returned (i.e., a state transfer is in progress), this method will return the current Address from which a state transfer is being attempted.
getCurrentStateTransferSource() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getCustomInterceptors() - Method in class org.infinispan.config.Configuration
Returns the CustomInterceptorConfig, if any, associated with this configuration object.
getCustomMarshallerVersionInt() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
getData() - Method in interface org.infinispan.tree.Node
Returns a map containing the data in this Node.
getData(Flag...) - Method in interface org.infinispan.tree.Node
 
getData() - Method in class org.infinispan.tree.NodeImpl
 
getData(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getData(Fqn) - Method in interface org.infinispan.tree.TreeCache
Retrieves a defensively copied data map of the underlying node.
getData(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getData(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
getData(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getDataColumnName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDataColumnType() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDataContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getDataContainer() - Method in interface org.infinispan.AdvancedCache
 
getDataContainer() - Method in class org.infinispan.CacheDelegate
 
getDefaultConfiguration() - Method in class org.infinispan.config.GlobalConfiguration
 
getDefaultFactoryMap() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getDefaultFactoryMap() - Method in class org.infinispan.factories.ComponentRegistry
 
getDefaultScope() - Static method in enum org.infinispan.factories.scopes.Scopes
 
getDefinedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDelegate() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
getDeleteAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDeleteExpiredRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDeleteRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDistributedSync() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getDistributedSync() - Method in interface org.infinispan.remoting.transport.Transport
 
getDistributedSyncTimeout() - Method in class org.infinispan.config.GlobalConfiguration
 
getDocumentRoot(InputStream) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns the root element of a given input stream
getDriverClass() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getElapsedTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getElementContent(Element, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of the element passed in.
getElementsCount() - Method in class org.infinispan.remoting.ReplicationQueue
 
getEmsConnection(Configuration) - Method in class org.infinispan.jopr.infinispan.ConnectionHelper
 
getEnlistedResources() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getEntry(Object) - Method in class org.infinispan.loaders.bucket.Bucket
 
getErroneousAttributes() - Method in exception org.infinispan.config.ConfigurationException
 
getEvictionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getEvictionManager() - Method in interface org.infinispan.AdvancedCache
 
getEvictionManager() - Method in class org.infinispan.CacheDelegate
 
getEvictionMaxEntries() - Method in class org.infinispan.config.Configuration
 
getEvictions() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getEvictionScheduledExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getEvictionScheduledExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getEvictionStrategy() - Method in class org.infinispan.config.Configuration
 
getEvictionWakeUpInterval() - Method in class org.infinispan.config.Configuration
 
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in interface org.infinispan.executors.ExecutorFactory
 
getExpirationLifespan() - Method in class org.infinispan.config.Configuration
 
getExpirationMaxIdle() - Method in class org.infinispan.config.Configuration
 
getExpiryDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getExpiryTime() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getExpiryTime() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Only used with entries that have a lifespan, this determines when an entry is due to expire.
getExpiryTime() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getFactory(Class) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component factory instance capable of constructing components of a specified type.
getFetchSize() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
getFetchSize() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getFetchSize() - Method in class org.infinispan.loaders.jdbc.TableManipulation
For DB queries (e.g.
getFirstCacheLoaderConfig() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
getFirstChildElement(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Gets the first child element of an element
getFirstInChain() - Method in class org.infinispan.interceptors.InterceptorChain
 
getFlags() - Method in interface org.infinispan.context.FlagContainer
 
getFlags() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
getFormatId() - Method in class org.infinispan.transaction.tm.DummyXid
 
getFqn() - Method in interface org.infinispan.tree.Node
Returns the Fqn which represents the location of this Node in the cache structure.
getFqn() - Method in class org.infinispan.tree.NodeImpl
 
getFromConfiguration(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component from the Configuration or RuntimeConfig.
getGlobalComponentRegistry() - Method in class org.infinispan.factories.ComponentRegistry
 
getGlobalConfiguration() - Method in class org.infinispan.config.Configuration
 
getGlobalTransaction() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getGlobalTransaction() - Method in interface org.infinispan.commands.tx.TransactionBoundaryCommand
 
getGlobalTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getGlobalTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getGlobalTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the id of the transaction assoctiated with the current call.
getGlobalTransaction() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getGlobalTransaction() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
 
getGlobalTransaction() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the transaction identifier.
getGlobalTransaction() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
getGlobalTransaction() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyXid
 
getGlobalTx() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getHitRatio() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getHits() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getHoldCount() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
getId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getIdColumnName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getIdColumnType() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getIndex() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getInsertRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getInstance() - Static method in class org.infinispan.container.entries.NullMarkerEntry
 
getInstance() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getInstance(ComponentRegistry, Configuration) - Static method in class org.infinispan.factories.InterceptorChainFactory
 
getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
getInstance() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getInstance(Class<T>) - Static method in class org.infinispan.util.Util
 
getInstance(String) - Static method in class org.infinispan.util.Util
 
getInt(String) - Method in class org.infinispan.config.parsing.XmlParserBase
 
getInterceptor() - Method in class org.infinispan.config.CustomInterceptorConfig
Returns a the interceptor that we want to add to the chain.
getInterceptorChain() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getInterceptorChain() - Method in interface org.infinispan.AdvancedCache
Retrieves the current Interceptor chain.
getInterceptorChain() - Method in class org.infinispan.CacheDelegate
 
getInterceptorsWhichExtend(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Returns all interceptors which extend the given command interceptor.
getInterceptorsWithClassName(String) - Method in class org.infinispan.interceptors.InterceptorChain
Returns all the interceptors that have the fully qualified name of their class equal with the supplied class name.
getIntProperty(String, int) - Method in class org.infinispan.util.TypedProperties
 
getInvalidations() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
Returns the InvocationContext that is currently associated with the calling thread.
getInvocationContext() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
getInvocationContextContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getInvocationContextContainer() - Method in interface org.infinispan.AdvancedCache
 
getInvocationContextContainer() - Method in class org.infinispan.CacheDelegate
 
getIsolationLevel() - Method in class org.infinispan.config.Configuration
 
getJGroupsAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
getJmxDomain() - Method in class org.infinispan.config.GlobalConfiguration
 
getKey() - Method in interface org.infinispan.commands.DataCommand
 
getKey() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getKey() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKey() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getKey() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the key to this entry
getKey() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getKey() - Method in class org.infinispan.loaders.modifications.Remove
 
getKey() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
getKey() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getKey() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
getKey() - Method in class org.infinispan.util.SimpleImmutableEntry
 
getKey2StringMapper() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getKeys() - Method in class org.infinispan.commands.LockControlCommand
 
getKeys() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKeys() - Method in interface org.infinispan.tree.Node
Returns a Set containing the data in this Node.
getKeys(Flag...) - Method in interface org.infinispan.tree.Node
 
getKeys() - Method in class org.infinispan.tree.NodeImpl
 
getKeys(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getKeys(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes in a String represenation of the Fqn.
getKeys(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getKeys(Fqn) - Method in interface org.infinispan.tree.TreeCache
Returns a set of attribute keys for the Fqn.
getKeys(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getKeys(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeys(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeys(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeys(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
GetKeyValueCommand - Class in org.infinispan.commands.read
// TODO: MANIK: Document this
GetKeyValueCommand(Object, CacheNotifier) - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
GetKeyValueCommand() - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
getL1Lifespan() - Method in class org.infinispan.config.Configuration
 
getLastElement() - Method in class org.infinispan.tree.Fqn
 
getLastElementAsString() - Method in class org.infinispan.tree.Fqn
If this is the root, returns Fqn.SEPARATOR.
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getLength() - Method in class org.infinispan.io.ByteBuffer
 
getLength() - Static method in class org.infinispan.Version
 
getLifespan() - Method in interface org.infinispan.container.entries.CacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLifespan() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getLifespan() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getLifespanMillis() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getLifespanMillis() - Method in class org.infinispan.commands.write.PutMapCommand
 
getLifespanMillis() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getListenerCollectionForAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getListeners() - Method in class org.infinispan.AbstractDelegatingCache
 
getListeners() - Method in class org.infinispan.CacheDelegate
 
getListeners() - Method in class org.infinispan.manager.DefaultCacheManager
 
getListeners() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getListeners() - Method in interface org.infinispan.notifications.Listenable
 
getLoadAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLocalAddress() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getLocalAddress() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getLocalComponent(Class<T>, String) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalComponent(Class<T>) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalTxCount() - Method in class org.infinispan.transaction.xa.TransactionTable
 
getLocation() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getLocation() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getLocation() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
getLockAcquisitionTimeout() - Method in class org.infinispan.config.Configuration
 
getLockAcquistionTimeout() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getLockAcquistionTimeout() - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
getLockConcurrencyLevel() - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
Returns number of threads expected to use this class concurrently.
getLockFromKey(Object) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
For BucketBasedCacheStores the lock should be acquired at bucket level.
getLockFromKey(Object) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getLockFromKey(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
getLockOwner() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getLockOwner() - Method in interface org.infinispan.context.InvocationContext
Returns the in behalf of which locks will be aquired.
getLog() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getLog() - Method in class org.infinispan.factories.ComponentRegistry
 
getLog() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getLog() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getLog() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getLog() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getLog(Class) - Static method in class org.infinispan.util.logging.LogFactory
 
getLog(String) - Static method in class org.infinispan.util.logging.LogFactory
 
getLong(String) - Method in class org.infinispan.config.parsing.XmlParserBase
 
getLongProperty(String, long) - Method in class org.infinispan.util.TypedProperties
 
getLookedUpEntries() - Method in interface org.infinispan.context.EntryLookup
Retrieves a map of entries looked up within the current scope.
getLookedUpEntries() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getLookedUpEntries() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
getLookedUpEntries() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getMajorVersion() - Static method in class org.infinispan.Version
 
getMap() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMarshaller() - Method in class org.infinispan.loaders.AbstractCacheStore
 
getMarshallerClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getMarshallVersion() - Method in class org.infinispan.config.GlobalConfiguration
 
getMarshallVersionString() - Method in class org.infinispan.config.GlobalConfiguration
 
getMaxConnections() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getMaxDoublingSize() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxIdle() - Method in interface org.infinispan.container.entries.CacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getMaxIdle() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getMaxIdleTimeMillis() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getMaxIdleTimeMillis() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMaxIdleTimeMillis() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getMaxTxRetries() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getMBeanInfo() - Method in class org.infinispan.jmx.ResourceDMBean
 
getMBeanServer() - Method in interface org.infinispan.jmx.MBeanServerLookup
 
getMBeanServer() - Method in class org.infinispan.jmx.PlatformMBeanServerLookup
 
getMBeanServerLookup() - Method in class org.infinispan.config.GlobalConfiguration
 
getMembers() - Method in interface org.infinispan.manager.CacheManager
 
getMembers() - Method in class org.infinispan.manager.DefaultCacheManager
 
getMembers() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMembers() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getMembers() - Method in interface org.infinispan.remoting.transport.Transport
Returns a list of members in the current cluster view.
getMisses() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getModifications() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getModifications() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getModifications() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns all the modifications performed in the scope of the current transaction.
getModifications() - Method in class org.infinispan.transaction.TransactionLog.LogEntry
 
getModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the modifications visible within the current transaction.
getModifications() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
getModifications() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getModificationsCount() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getName() - Method in class org.infinispan.AbstractDelegatingCache
 
getName() - Method in interface org.infinispan.Cache
Retrieves the name of the cache
getName() - Method in class org.infinispan.CacheDelegate
 
getName() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getName() - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
 
getName() - Method in interface org.infinispan.loaders.s3.S3Bucket
 
getNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNewBufferSize(int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the number of bytes to which the internal buffer should be resized.
getNewMemberList() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getNewMemberList() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getNext(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Retrieves the next entry after a given entry, skipping marked entries accordingly.
getNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Retrieves the next interceptor in the chain.
getNode(Fqn) - Method in interface org.infinispan.tree.TreeCache
A convenience method to retrieve a node directly from the cache.
getNode(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getNode(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
getNode(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getNode(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNode(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNode(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNode(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNonClusteredDefault() - Static method in class org.infinispan.config.GlobalConfiguration
Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
getNumberOfEntries() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getNumberOfLocksAvailable() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumberOfLocksHeld() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
getNumLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
getNumOwners() - Method in class org.infinispan.config.Configuration
 
getObjectName(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName(String, String, String) - Static method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName() - Method in class org.infinispan.jmx.ResourceDMBean
 
getObjectWriter(Object) - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
getOffset() - Method in class org.infinispan.io.ByteBuffer
 
getOrCreateComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a 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(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getOrCreateXaAdapter(Transaction, InvocationContext) - Method in class org.infinispan.transaction.xa.TransactionTable
Returns the TransactionXaAdapter corresponding to the supplied transaction.
getOwner(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the write lock owner, if any, for the specified cache entry.
getOwner(Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getOwner() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
getParameters() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getParameters() - Method in class org.infinispan.commands.LockControlCommand
 
getParameters() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getParameters() - Method in class org.infinispan.commands.read.SizeCommand
 
getParameters() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getParameters() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getParameters() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getParameters() - Method in interface org.infinispan.commands.ReplicableCommand
Used by marshallers to stream this command across a network
getParameters() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getParameters() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getParameters() - Method in class org.infinispan.commands.write.ClearCommand
 
getParameters() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getParameters() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getParameters() - Method in class org.infinispan.commands.write.PutMapCommand
 
getParameters() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getParent() - Method in class org.infinispan.tree.Fqn
Returns the parent of this Fqn.
getParent() - Method in interface org.infinispan.tree.Node
Returns the parent node.
getParent(Flag...) - Method in interface org.infinispan.tree.Node
 
getParent() - Method in class org.infinispan.tree.NodeImpl
 
getParent(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getPassivations() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
getPassword() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getPassword() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getPollWait() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getPooledDataSource() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
getPrepares() - Method in class org.infinispan.interceptors.TxInterceptor
 
getPrev(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Retrieves the previous entry befora a given entry, skipping marked entries accordingly.
getProperties() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
getProxy(Cache, Object, BatchContainer, InvocationContextContainer) - Method in class org.infinispan.atomic.AtomicHashMap
 
getProxyHost() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getProxyPort() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getPushStateTimeout() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
getQueueSize() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getRaw() - Method in class org.infinispan.marshall.MarshalledValue
 
getRawBuffer() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the internal buffer array.
getReadWriteRatio() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getReferencedObject(int) - Method in class org.infinispan.marshall.UnmarshalledReferences
Retrieves an object referenced by an id
getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Returns an immutable set contating all the components that exists in the reporsitory at this moment.
getRehashWaitTime() - Method in class org.infinispan.config.Configuration
 
getRemoteCallTimeout() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.TransactionTable
Returns the RemoteTransaction associated with the supplied transaction id.
getRemoteTxCount() - Method in class org.infinispan.transaction.xa.TransactionTable
 
getReplicationCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getReplicationFailures() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getReplicationQueueScheduledExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getReplicationQueueScheduledExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getReplQueueInterval() - Method in class org.infinispan.config.Configuration
 
getReplQueueMaxElements() - Method in class org.infinispan.config.Configuration
 
getRequestTimeout() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DefaultResponseGenerator
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
getResponse() - Method in class org.infinispan.remoting.responses.ExtendedResponse
 
getResponse(CacheRpcCommand, Object) - Method in interface org.infinispan.remoting.responses.ResponseGenerator
 
getResponseValue() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
getRollbacks() - Method in class org.infinispan.interceptors.TxInterceptor
 
getRoot() - Method in class org.infinispan.loaders.file.FileCacheStore
 
getRoot() - Method in interface org.infinispan.tree.TreeCache
Returns the root node of this cache.
getRoot(Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getRoot() - Method in class org.infinispan.tree.TreeCacheImpl
 
getRoot(Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getRowCount() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getRowCount() - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getRpcManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getRpcManager() - Method in interface org.infinispan.AdvancedCache
 
getRpcManager() - Method in class org.infinispan.CacheDelegate
 
getRPCManager() - Method in class org.infinispan.config.RuntimeConfig
 
getRunningTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getRunningTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getRunningTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the tx associated with the current thread.
getScheduledExecutor(Properties) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties) - Method in interface org.infinispan.executors.ScheduledExecutorFactory
 
getSelectExpiredRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getSelectRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getSetStateException() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
getSharedLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getShutdownHookBehavior() - Method in class org.infinispan.config.GlobalConfiguration
 
getSingleElement(String, String, Element) - Method in class org.infinispan.config.parsing.XmlParserBase
Convenient method for retrieving a single element with the give name.
getSingleElementInCoreNS(String, Element) - Method in class org.infinispan.config.parsing.XmlParserBase
Convenient method for retrieving a single element with the give name, in the core namespace
getSingletonStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getSingletonStoreConfig() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getState() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getState(String) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getState(OutputStream) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getState(String, OutputStream) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getStateRetrievalTimeout() - Method in class org.infinispan.config.Configuration
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
Returns whether an interceptor's statistics are being captured.
getStatisticsEnabled() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.TxInterceptor
 
getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Returns whether an interceptor's statistics are being captured.
getStatus() - Method in class org.infinispan.AbstractDelegatingCache
 
getStatus() - Method in interface org.infinispan.Cache
 
getStatus() - Method in class org.infinispan.CacheDelegate
 
getStatus() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the state of the registry
getStatus() - Method in interface org.infinispan.manager.CacheManager
 
getStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStatus() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Get the status of the transaction associated with the calling thread.
getStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Get the status of the transaction.
getStoredEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getStoredEntry() - Method in class org.infinispan.loaders.modifications.Store
 
getStores() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getStores() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
getStream() - Method in class org.infinispan.io.ByteBuffer
 
getStreamBufferSize() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getStringMapping(Object) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultKey2StringMapper
Returns key.toString.
getStringMapping(Object) - Method in interface org.infinispan.loaders.jdbc.stringbased.Key2StringMapper
Must return an unique String for the supplied key.
getStringRepresentation(List) - Method in class org.infinispan.tree.Fqn
 
getSubElement(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns a named sub-element of the current element passed in.
getSubFqn(int, int) - Method in class org.infinispan.tree.Fqn
Obtains a sub-Fqn from the given Fqn.
getSuccessRatio() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSyncReplTimeout() - Method in class org.infinispan.config.Configuration
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getTableName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTagContents(Element, String, String, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns the contents of a specific node of given element name, provided a certain attribute exists and is set to value.
getterMethod(Class, Class) - Static method in class org.infinispan.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.infinispan.util.BeanUtils
Returns a getter for a given class
getThreadPoolSize() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getTimeSinceReset() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getTimestampColumnName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTimestampColumnType() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTotalLockCount() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
getTotalLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
Returns the total number of locks held by this class.
getTotalReadLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getTotalWriteLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getTransaction() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Get the transaction associated with the calling thread.
getTransaction() - Method in class org.infinispan.transaction.TransactionLog.LogEntry
 
getTransaction() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getTransactionManager() - Method in class org.infinispan.config.RuntimeConfig
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
Get the systemwide used TransactionManager
getTransactionManager() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.JBossTransactionManagerLookup
 
getTransactionManager() - Method in interface org.infinispan.transaction.lookup.TransactionManagerLookup
Returns a new TransactionManager.
getTransactionManagerLookupClass() - Method in class org.infinispan.config.Configuration
 
getTransactionParticipants() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getTransactionParticipants() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the set of cluster participants (identified through Address objects) that participate within the transaction.
getTransactionTimeout() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getTransport() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTransport() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTransportClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getTransportProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getType() - Method in class org.infinispan.loaders.modifications.Clear
 
getType() - Method in interface org.infinispan.loaders.modifications.Modification
 
getType() - Method in class org.infinispan.loaders.modifications.PurgeExpired
 
getType() - Method in class org.infinispan.loaders.modifications.Remove
 
getType() - Method in class org.infinispan.loaders.modifications.Store
 
getType() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getUpdateRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getUserName() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getUserName() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getUserTransaction() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getValue() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getValue() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getValue() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the value of this entry
getValue() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getValue() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
 
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
 
getValue() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getValue() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
getValue(Object, String) - Static method in class org.infinispan.util.ReflectionUtil
Retrieves the value of a field of an object instance via reflection
getValue() - Method in class org.infinispan.util.SimpleImmutableEntry
 
getValueAt(int, int) - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getValueAt(int, int) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getValues(MeasurementReport, Set<MeasurementScheduleRequest>) - Method in class org.infinispan.jopr.infinispan.CacheComponent
Gather measurement data
getValues(MeasurementReport, Set<MeasurementScheduleRequest>) - Method in class org.infinispan.jopr.infinispan.InfinispanComponent
Gather measurement data
getVersion() - Method in class org.infinispan.AbstractDelegatingCache
 
getVersion() - Method in interface org.infinispan.Cache
Retrieves the version of Infinispan
getVersion() - Method in class org.infinispan.CacheDelegate
 
getVersion() - Method in class org.infinispan.manager.DefaultCacheManager
 
getVersionShort() - Static method in class org.infinispan.Version
 
getVersionShort(String) - Static method in class org.infinispan.Version
 
getXaCacheAdapter(Transaction) - Method in class org.infinispan.transaction.xa.TransactionTable
 
GLOBAL_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheManagerJmxRegistration
 
globalComponentRegistry - Variable in class org.infinispan.factories.AbstractComponentFactory
 
GlobalComponentRegistry - Class in org.infinispan.factories
A global component registry where shared components are stored.
GlobalComponentRegistry(GlobalConfiguration, CacheManager) - Constructor for class org.infinispan.factories.GlobalComponentRegistry
Creates an instance of the component registry.
GlobalConfiguration - Class in org.infinispan.config
Configuration component that encapsulates the global configuration.
GlobalConfiguration() - Constructor for class org.infinispan.config.GlobalConfiguration
 
globalConfiguration - Variable in class org.infinispan.factories.AbstractComponentFactory
 
globalConfiguration - Variable in class org.infinispan.manager.DefaultCacheManager
 
GlobalConfiguration.ShutdownHookBehavior - Enum in org.infinispan.config
Behavior of the JVM shutdown hook registered by the cache
GlobalTransaction - Class in org.infinispan.transaction.xa
Uniquely identifies a transaction that spans all JVMs in a cluster.
GlobalTransaction() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
empty ctor used by externalization.
GlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
 
GlobalTransaction(long, Address) - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
 
GlobalTransaction(boolean) - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
 
GlobalTransactionExternalizer - Class in org.infinispan.marshall.jboss.externalizers
GlobalTransactionExternalizer.
GlobalTransactionExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.GlobalTransactionExternalizer
 
globalTx - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 

H

handle(CacheRpcCommand) - Method in interface org.infinispan.remoting.InboundInvocationHandler
Invokes a command on the cache, from a remote source.
handle(CacheRpcCommand) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
handle(Message) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
Message contains a Command.
handleClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleCommitCommand(InvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
A default handler for all commands visited.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
The default behaviour of the visitXXX methods, which is to ignore the call and pass the call up to the next interceptor in the chain.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.BatchingInterceptor
Simply check if there is an ongoing tx.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
handleEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePrepareCommand(InvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRollbackCommand(InvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleViewChange(ViewChangedEvent) - Method in class org.infinispan.distribution.DistributionManagerImpl.ViewChangeListener
 
hasChild(Fqn) - Method in interface org.infinispan.tree.Node
Returns true if the child node denoted by the relative Fqn passed in exists.
hasChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
hasChild(Object) - Method in interface org.infinispan.tree.Node
Returns true if the child node denoted by the Object name passed in exists.
hasChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
hasChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
hasChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
hasChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
hasChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
hasComponentStarted() - Method in class org.infinispan.config.AbstractConfigurationBean
Tests whether the component this configuration bean intents to configure has already started.
hasComponentStarted() - Method in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
hasComponentStarted() - Method in class org.infinispan.config.GlobalConfiguration
 
hasElement(Object) - Method in class org.infinispan.tree.Fqn
 
hasFlag(Flag) - Method in interface org.infinispan.context.FlagContainer
 
hasFlag(Flag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
hash(Object) - Static method in class org.infinispan.util.AbstractMap
 
hashCode() - Method in class org.infinispan.commands.LockControlCommand
 
hashCode() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
hashCode() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
hashCode() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
hashCode() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
hashCode() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
hashCode() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
hashCode() - Method in class org.infinispan.commands.write.PutMapCommand
 
hashCode() - Method in class org.infinispan.commands.write.RemoveCommand
 
hashCode() - Method in class org.infinispan.commands.write.ReplaceCommand
 
hashCode() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
hashCode() - Method in class org.infinispan.config.Configuration
 
hashCode() - Method in class org.infinispan.config.CustomInterceptorConfig
 
hashCode() - Method in class org.infinispan.config.GlobalConfiguration
 
hashCode() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
hashCode() - Method in class org.infinispan.config.RuntimeConfig
 
hashCode() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
hashCode() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
hashCode() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
hashCode() - Method in class org.infinispan.loaders.modifications.Remove
 
hashCode() - Method in class org.infinispan.loaders.modifications.Store
 
hashCode() - Method in class org.infinispan.marshall.MarshalledValue
 
hashCode() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
hashCode() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
hashCode() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
hashCode() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
hashCode() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
hashCode() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
hashCode() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
hashCode() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
hashCode() - Method in class org.infinispan.tree.Fqn
Returns a hash code with Fqn elements.
hashCode() - Method in class org.infinispan.tree.NodeImpl
 
hashCode() - Method in class org.infinispan.tree.NodeKey
 
hashCode() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
hashCode() - Method in class org.infinispan.util.SimpleImmutableEntry
 
hashCode() - Method in class org.infinispan.util.Util.MapModifications
 
hashCodeExcludingProperties() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
hasLockedEntries() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
hasLockedEntries() - Method in interface org.infinispan.context.InvocationContext
Returns true if the context has any locked entries associated with it.
hasLockedKey(Object) - Method in interface org.infinispan.context.EntryLookup
Using this method should always ensure locks checked in the appropriate scope.
hasLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
hasModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
hasModifications() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
hasModifications() - Method in interface org.infinispan.context.impl.TxInvocationContext
Were there any modifications performed within the tx's scope?
hasNext() - Method in class org.infinispan.container.FIFODataContainer.LinkedIterator
 
hasNext() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer.LinkedIterator
 
hasNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
hasPendingPrepare(PrepareCommand) - Method in class org.infinispan.transaction.TransactionLog
 
HORIZON_NS - Static variable in class org.infinispan.config.parsing.RootElementBuilder
 

I

icc - Variable in class org.infinispan.CacheDelegate
 
icc - Variable in class org.infinispan.commands.remote.BaseRpcCommand
 
icc - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
immediateLockForWriting(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Same as LockSupportCacheStore.lockForWriting(String), but with 0 timeout.
ImmortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is immortal/cannot expire
ImmortalCacheEntryExternalizer - Class in org.infinispan.marshall.jboss.externalizers
ImmortalCacheEntryExternalizer.
ImmortalCacheEntryExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ImmortalCacheEntryExternalizer
 
ImmortalCacheValue - Class in org.infinispan.container.entries
An immortal cache value, to correspond with ImmortalCacheEntry
ImmortalCacheValueExternalizer - Class in org.infinispan.marshall.jboss.externalizers
ImmortalCacheValueExternalizer.
ImmortalCacheValueExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ImmortalCacheValueExternalizer
 
immutableCollectionCopy(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Creates a new immutable copy of the specified Collection.
immutableListConvert(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Converts a Collection to an immutable List by copying it.
ImmutableListCopy<E> - Class in org.infinispan.util
A lightweight, read-only copy of a List.
ImmutableListCopy() - Constructor for class org.infinispan.util.ImmutableListCopy
Constructs a new ImmutableListCopy.
ImmutableListCopy(Collection<? extends E>) - Constructor for class org.infinispan.util.ImmutableListCopy
Only one copy constructor since the list is immutable.
ImmutableListCopy(E[]) - Constructor for class org.infinispan.util.ImmutableListCopy
Assumes that the array passed in is "safe", i.e., is not referenced from elsewhere.
ImmutableListCopy(Collection<? extends E>, Collection<? extends E>) - Constructor for class org.infinispan.util.ImmutableListCopy
Utility constructors to allow combining collections
immutableListCopy(List<? extends T>) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the list.
immutableListMerge(List<? extends T>, List<? extends T>) - Static method in class org.infinispan.util.Immutables
Creates a new immutable list containing the union (combined entries) of both lists.
immutableListWrap(T...) - Static method in class org.infinispan.util.Immutables
Wraps an array with an immutable list.
immutableMapCopy(Map<? extends K, ? extends V>) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the specified map.
ImmutableMapExternalizer - Class in org.infinispan.marshall.jboss.externalizers
ImmutableExternalizer.
ImmutableMapExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ImmutableMapExternalizer
 
immutableMapWrap(Map<? extends K, ? extends V>) - Static method in class org.infinispan.util.Immutables
Wraps a map with an immutable map.
immutableReversibleOrderedSetCopy(ReversibleOrderedSet<T>) - Static method in class org.infinispan.util.Immutables
 
Immutables - Class in org.infinispan.util
Factory for generating immutable type wrappers.
Immutables() - Constructor for class org.infinispan.util.Immutables
 
Immutables.Immutable - Interface in org.infinispan.util
 
immutableSetConvert(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Converts a Collections into an immutable Set by copying it.
immutableSetCopy(Set<? extends T>) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the specified set.
immutableSetWrap(Set<? extends T>) - Static method in class org.infinispan.util.Immutables
Wraps a set with an immutable set.
ImplicitEagerLockingInterceptor - Class in org.infinispan.interceptors
Interceptor in charge of eager, implicit locking of cache keys across cluster within transactional context
ImplicitEagerLockingInterceptor() - Constructor for class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
InboundInvocationHandler - Interface in org.infinispan.remoting
A globally scoped component, that is able to locate named caches and invoke remotely originating calls on the appropriate cache.
InboundInvocationHandlerImpl - Class in org.infinispan.remoting
Sets the cache interceptor chain on an RPCCommand before calling it to perform
InboundInvocationHandlerImpl() - Constructor for class org.infinispan.remoting.InboundInvocationHandlerImpl
 
IncorrectListenerException - Exception in org.infinispan.notifications
Thrown when an incorrectly annotated class is added as a cache listener using the Listenable.addListener(Object) API.
IncorrectListenerException(String) - Constructor for exception org.infinispan.notifications.IncorrectListenerException
 
indexOf(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
InfinispanCollections - Class in org.infinispan.util
Static helpers for Infinispan-specific collections
InfinispanCollections() - Constructor for class org.infinispan.util.InfinispanCollections
 
InfinispanComponent - Class in org.infinispan.jopr.infinispan
The component class for the Infinispan manager
InfinispanComponent() - Constructor for class org.infinispan.jopr.infinispan.InfinispanComponent
 
InfinispanDemo - Class in org.infinispan.demo
 
InfinispanDemo(String) - Constructor for class org.infinispan.demo.InfinispanDemo
 
InfinispanDemo.AlternateColorTable - Class in org.infinispan.demo
 
InfinispanDemo.AlternateColorTable() - Constructor for class org.infinispan.demo.InfinispanDemo.AlternateColorTable
 
InfinispanDemo.CachedDataTableModel - Class in org.infinispan.demo
 
InfinispanDemo.CachedDataTableModel() - Constructor for class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
InfinispanDemo.CacheListener - Class in org.infinispan.demo
 
InfinispanDemo.CacheListener() - Constructor for class org.infinispan.demo.InfinispanDemo.CacheListener
 
InfinispanDemo.ClusterTableModel - Class in org.infinispan.demo
 
InfinispanDemo.ClusterTableModel() - Constructor for class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
InfinispanDiscovery - Class in org.infinispan.jopr.infinispan
Discovery class for Infinispan engines
InfinispanDiscovery() - Constructor for class org.infinispan.jopr.infinispan.InfinispanDiscovery
 
info(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
info(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
info(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
info(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
info(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
info(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
info(Object) - Method in interface org.infinispan.util.logging.Log
 
info(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
info(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
info(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
init(Transport) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
init(InterceptorChain, InvocationContextContainer) - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
init(InterceptorChain, InvocationContextContainer, TransactionTable) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.ClearCommand
 
init(DistributionManager, CacheNotifier) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.PutMapCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.RemoveCommand
 
init(TransactionManager, TransactionTable) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
init(Configuration, RpcManager, CacheManagerNotifier, CommandsFactory) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
init() - Method in class org.infinispan.factories.EntryFactoryImpl
 
init(RpcManager) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
init() - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
init(CacheLoaderManager) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
init(CommandsFactory) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
init(TransactionManager, TransactionTable, TransactionLog) - Method in class org.infinispan.interceptors.TxInterceptor
 
init(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.AbstractCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Used to initialize a cache loader. This implementation expects config to be an instance of BdbjeCacheStoreConfig

note that the m is not currently used as SleepyCat has its own efficient solution.

init(CacheLoaderConfig, Cache, Marshaller) - Method in interface org.infinispan.loaders.CacheLoader
Used to initialize a cache loader.
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.file.FileCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
init(JCloudsConnection, S3Bucket) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
 
init(C, B) - Method in interface org.infinispan.loaders.s3.S3Bucket
Creates a connection to S3, and associates this object with an S3Bucket.
init(CacheLoaderConfig, Cache, Marshaller) - Method in class org.infinispan.loaders.s3.S3CacheStore
Used to initialize a cache loader. This initializes the internal s3Connection to a default implementation
init(CacheLoaderConfig, Cache, Marshaller, S3Connection, S3Bucket) - Method in class org.infinispan.loaders.s3.S3CacheStore
 
init() - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
init(RemoteCommandFactory) - Method in class org.infinispan.marshall.jboss.externalizers.ReplicableCommandExternalizer
 
init(Transport) - Method in class org.infinispan.marshall.jboss.externalizers.StateTransferControlCommandExternalizer
Deprecated.  
init(ClassLoader, RemoteCommandFactory) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
init(byte[], int) - Method in class org.infinispan.marshall.MarshalledValue
 
init(ClassLoader, RemoteCommandFactory) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
init(ClassLoader, RemoteCommandFactory) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
initForWriting() - Method in class org.infinispan.atomic.AtomicHashMap
Initializes the delta instance to start recording changes.
initialize(DataContainer, CacheLoaderManager, InvocationContextContainer) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
initialize(CacheNotifier) - Method in class org.infinispan.commands.tx.PrepareCommand
 
initialize(CacheNotifier) - Method in class org.infinispan.commands.write.EvictCommand
 
initialize(String) - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Initializes the parser with a String that represents the name of the configuration file to parse.
initialize(InputStream) - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Initializes the parser with a stream that contains the contents of an XML configuration file to parse.
initialize(String) - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
 
initialize(InputStream) - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
 
initialize(ScheduledExecutorService, Configuration, Cache, DataContainer, CacheLoaderManager) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
initialize(InvocationContextContainer) - Method in class org.infinispan.interceptors.InterceptorChain
 
initialize(AdvancedCache) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
initialize(GlobalConfiguration, Marshaller, ExecutorService, InboundInvocationHandler, CacheManagerNotifier) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
initialize(GlobalConfiguration, Marshaller, ExecutorService, InboundInvocationHandler, CacheManagerNotifier) - Method in interface org.infinispan.remoting.transport.Transport
Initializes the transport with global cache configuration and transport-specific properties.
initialize(CommandsFactory, RpcManager, Configuration, InvocationContextContainer, InterceptorChain, CacheNotifier) - Method in class org.infinispan.transaction.xa.TransactionTable
 
initializeReplicableCommand(ReplicableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Initializes a ReplicableCommand read from a data stream with components specific to the target cache instance.
initializeReplicableCommand(ReplicableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
initLinks() - Method in class org.infinispan.container.FIFODataContainer
Initializes links to an empty container
initLinks() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
Initializes links to an empty container
initLocks(int) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
initLocks(int) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
initLocks(int) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
initLogger() - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
inject(Transport) - Method in class org.infinispan.commands.RemoteCommandFactory
 
Inject - Annotation Type in org.infinispan.factories.annotations
Used to annotate a method as one that is used to inject a registered component into another component.
inject(Cache, Marshaller, Configuration) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
inject(GlobalComponentRegistry) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
injectCacheManager(CacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
injectDependencies(EvictionManager, InvocationContextContainer, CommandsFactory, InterceptorChain, Configuration, CacheNotifier, ComponentRegistry, TransactionManager, BatchContainer, RpcManager, DataContainer, Marshaller, ResponseGenerator, CacheManager, StateTransferManager) - Method in class org.infinispan.CacheDelegate
 
injectDependencies() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Injects dependencies into this component.
injectDependencies(DataContainer, LockManager, Configuration, CacheNotifier) - Method in class org.infinispan.factories.EntryFactoryImpl
 
injectDependencies(CacheLoaderManager, DataContainer, EntryFactory, CacheNotifier) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
injectDependencies(DistributionManager, CommandsFactory, DataContainer) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
injectDependencies(CommandsFactory) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
injectDependencies(CacheNotifier) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
injectDependencies(Transport, Configuration, ReplicationQueue, CommandsFactory, ExecutorService) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
injectDependencies(RpcManager, AdvancedCache, Configuration, DataContainer, CacheLoaderManager, Marshaller, TransactionLog, InterceptorChain, InvocationContextContainer, CommandsFactory, TransactionTable) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
injectDependencies(Configuration, TransactionManager, InvocationContextContainer) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
injectDistributionManager(DistributionManager) - Method in class org.infinispan.interceptors.DistLockingInterceptor
 
injectDistributionManager(DistributionManager, CommandsFactory) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
insert(Bucket) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
Adds the Infinispan bucket into the S3 Bucket at location Bucket.getBucketName()
insert(Bucket) - Method in interface org.infinispan.loaders.s3.S3Bucket
Adds the Infinispan bucket into the S3 Bucket at location Bucket.getBucketName()
insertBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.file.FileCacheStore
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.s3.S3CacheStore
 
INSTANCE - Static variable in class org.infinispan.atomic.NullDelta
 
instance - Variable in class org.infinispan.marshall.MarshalledValue
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.RequestIgnoredResponse
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
instance - Static variable in class org.infinispan.transaction.tm.DummyTransactionManager
 
INSTANCE - Static variable in class org.infinispan.tree.FqnComparator
 
interceptorChain - Variable in class org.infinispan.commands.remote.BaseRpcCommand
 
InterceptorChain - Class in org.infinispan.interceptors
Knows how to build and manage an chain of interceptors.
InterceptorChain(CommandInterceptor) - Constructor for class org.infinispan.interceptors.InterceptorChain
Constructs an interceptor chain having the supplied interceptor as first.
InterceptorChainFactory - Class in org.infinispan.factories
Factory class that builds an interceptor chain based on cache configuration.
InterceptorChainFactory() - Constructor for class org.infinispan.factories.InterceptorChainFactory
 
InternalCacheEntry - Interface in org.infinispan.container.entries
Interface for internal cache entries that expose whether an entry has expired.
InternalCacheFactory<K,V> - Class in org.infinispan.factories
An internal factory for constructing Caches.
InternalCacheFactory() - Constructor for class org.infinispan.factories.InternalCacheFactory
 
InternalCacheValue - Interface in org.infinispan.container.entries
A representation of an InternalCacheEntry that does not have a reference to the key.
InternalEntryFactory - Class in org.infinispan.container.entries
A factory for internal entries
InternalEntryFactory() - Constructor for class org.infinispan.container.entries.InternalEntryFactory
 
invalidate(InvocationContext, Object) - Method in class org.infinispan.commands.write.InvalidateCommand
 
invalidateAcrossCluster(boolean, InvocationContext, Object[], boolean, Object) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
InvalidateCommand - Class in org.infinispan.commands.write
Removes an entry from memory - never removes the entry.
InvalidateCommand() - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateCommand(CacheNotifier, Object...) - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateL1Command - Class in org.infinispan.commands.write
Invalidates an entry in a L1 cache (used with DIST mode)
InvalidateL1Command() - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(DistributionManager, CacheNotifier, Object...) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidationInterceptor - Class in org.infinispan.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.infinispan.interceptors.InvalidationInterceptor
 
InvalidationInterceptor.InvalidationFilterVisitor - Class in org.infinispan.interceptors
 
InvalidationInterceptor.InvalidationFilterVisitor(int) - Constructor for class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
InvalidResponse - Class in org.infinispan.remoting.responses
An invalid response
InvalidResponse() - Constructor for class org.infinispan.remoting.responses.InvalidResponse
 
InvocationContext - Interface in org.infinispan.context
A context that contains information pertaining to a given invocation.
InvocationContextContainer - Interface in org.infinispan.context
Manages the association between an InvocationContext and the calling thread.
InvocationContextContainerImpl - Class in org.infinispan.context
Default implementation for InvocationContextContainer.
InvocationContextContainerImpl() - Constructor for class org.infinispan.context.InvocationContextContainerImpl
 
InvocationContextInterceptor - Class in org.infinispan.interceptors
 
InvocationContextInterceptor() - Constructor for class org.infinispan.interceptors.InvocationContextInterceptor
 
invocationsAllowed(boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Asserts whether invocations are allowed on the cache or not.
invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.InterceptorChain
Walks the command through the interceptor chain.
invoke(String, Object[], String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
invoke(Object) - Method in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
invokeAccessibly(Object, Method, Object[]) - Static method in class org.infinispan.util.ReflectionUtil
Invokes a method using reflection, in an accessible manner (by using AccessibleObject.setAccessible(boolean)
invokeAll(Collection) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
invokeAll(Collection, long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
invokeAny(Collection) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
invokeAny(Collection, long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
invokeInjectionMethod(Object, Method) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
invokeNextInterceptor(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Invokes the next interceptor in the chain.
invokeOperation(String, Configuration) - Method in class org.infinispan.jopr.infinispan.CacheComponent
Invoke operations on the Cache MBean instance
invoker - Variable in class org.infinispan.CacheDelegate
 
invoker - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
invokeRemoteCommands(Vector<Address>, ReplicableCommand, int, long, boolean, boolean, RspFilter, boolean, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
Similar to RpcDispatcher.callRemoteMethods(java.util.Vector, org.jgroups.blocks.MethodCall, int, long, boolean, boolean, org.jgroups.blocks.RspFilter) except that this version is aware of ReplicableCommand objects.
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(List<Address>, ReplicableCommand, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to a specified set of recipients
invokeRemotely(List<Address>, ReplicableCommand, boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to a specified set of recipients
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(List<Address>, ReplicableCommand, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(List<Address>, ReplicableCommand, boolean, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeRemotely(List<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter, boolean) - Method in interface org.infinispan.remoting.transport.Transport
Invokes an RPC call on other caches in the cluster.
invokeRemotelyInFuture(List<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.List, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
invokeRemotelyInFuture(List<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.List, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
invokeRemotelyInFuture(List<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotelyInFuture(List<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
IS_LOG4J_AVAILABLE - Static variable in class org.infinispan.util.logging.LogFactory
 
isAcceptable(Response, Address) - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
isAcceptable(Response, Address) - Method in interface org.infinispan.remoting.rpc.ResponseFilter
Determines whether a response from a given sender should be added to the response list of the request
isAcceptable(Object, Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
 
isActive(Transaction) - Static method in class org.infinispan.context.impl.AbstractTxInvocationContext
Returns true if transaction is ACTIVE, false otherwise
isActive() - Method in class org.infinispan.transaction.TransactionLog
 
isAllowDuplicateDomains() - Method in class org.infinispan.config.GlobalConfiguration
 
isAnnotationPresent(Class, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
Tests whether an annotation is present on a class.
isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isCacheReady() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
A test to check whether the cache is in its started state.
isCancelled() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
isChanged() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isChanged() - Method in interface org.infinispan.container.entries.CacheEntry
 
isChanged() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isChildOf(Fqn) - Method in class org.infinispan.tree.Fqn
Returns true if this Fqn is child of parentFqn.
isChildOrEquals(Fqn) - Method in class org.infinispan.tree.Fqn
Returns true if this Fqn is equals or the child of parentFqn.
isClustered() - Method in enum org.infinispan.config.Configuration.CacheMode
 
isConditional() - Method in class org.infinispan.commands.write.ClearCommand
 
isConditional() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isConditional() - Method in class org.infinispan.commands.write.PutMapCommand
 
isConditional() - Method in class org.infinispan.commands.write.RemoveCommand
 
isConditional() - Method in class org.infinispan.commands.write.ReplaceCommand
 
isConditional() - Method in interface org.infinispan.commands.write.WriteCommand
Certain commands only work based on a certain condition or state of the cache.
isContextFlagSet(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Tests whether a context flag is set.
isCoordinator() - Method in interface org.infinispan.manager.CacheManager
 
isCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
 
isCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
isCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
isCreated() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isCreated() - Method in interface org.infinispan.container.entries.CacheEntry
 
isCreated() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isCreateTableOnStart() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
isDebugEnabled() - Method in class org.infinispan.util.logging.JDKLogImpl
 
isDebugEnabled() - Method in interface org.infinispan.util.logging.Log
 
isDebugEnabled() - Method in class org.infinispan.util.logging.Log4JLogImpl
 
isDirectChildOf(Fqn) - Method in class org.infinispan.tree.Fqn
Returns true if this Fqn is a direct child of a given Fqn.
isDistributed() - Method in enum org.infinispan.config.Configuration.CacheMode
 
isDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
isDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
isDropTableOnExit() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
isEmpty() - Method in class org.infinispan.AbstractDelegatingCache
 
isEmpty() - Method in class org.infinispan.atomic.AtomicHashMap
 
isEmpty() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
isEmpty() - Method in class org.infinispan.CacheDelegate
 
isEmpty() - Method in class org.infinispan.loaders.bucket.Bucket
 
isEmpty() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
isEmpty() - Method in class org.infinispan.util.FastCopyHashMap
 
isEmpty() - Method in class org.infinispan.util.ImmutableListCopy
 
isEmpty() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns true if this set contains no elements.
isEnabled() - Method in interface org.infinispan.eviction.EvictionManager
 
isEnabled() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
isEnabled() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isEnabled() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isEnabled() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
isEnabled() - Method in class org.infinispan.remoting.ReplicationQueue
 
isErrorEnabled() - Method in class org.infinispan.util.logging.JDKLogImpl
 
isErrorEnabled() - Method in interface org.infinispan.util.logging.Log
 
isErrorEnabled() - Method in class org.infinispan.util.logging.Log4JLogImpl
 
isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
isExpired() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
isExpired() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.MortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
isExplicit() - Method in class org.infinispan.commands.LockControlCommand
 
isExposeGlobalJmxStatistics() - Method in class org.infinispan.config.GlobalConfiguration
 
isExposeJmxStatistics() - Method in class org.infinispan.config.Configuration
 
isFatalEnabled() - Method in class org.infinispan.util.logging.JDKLogImpl
 
isFatalEnabled() - Method in interface org.infinispan.util.logging.Log
 
isFatalEnabled() - Method in class org.infinispan.util.logging.Log4JLogImpl
 
isFetchInMemoryState() - Method in class org.infinispan.config.Configuration
 
isFetchPersistentState() - Method in class org.infinispan.config.CacheLoaderManagerConfig
Loops through all individual cache loader configs and checks if fetchPersistentState is set on any of them
isFetchPersistentState() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isFetchPersistentState() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isFetchPersistentState() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isFetchPersistentState() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isFirst() - Method in class org.infinispan.config.CustomInterceptorConfig
 
isFlagSet(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Tests whether a flag is set.
isFlagsUninitialized() - Method in interface org.infinispan.context.FlagContainer
 
isFlagsUninitialized() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
isHeldExclusively() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
isIgnoreModifications() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isIgnoreModifications() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isImmutable(Object) - Static method in class org.infinispan.util.Immutables
Whether or not this collection type is immutable
isImplicit() - Method in class org.infinispan.commands.LockControlCommand
 
isInfoEnabled() - Method in class org.infinispan.util.logging.JDKLogImpl
 
isInfoEnabled() - Method in interface org.infinispan.util.logging.Log
 
isInfoEnabled() - Method in class org.infinispan.util.logging.Log4JLogImpl
 
isInTxScope() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
isInTxScope() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
isInTxScope() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
isInTxScope() - Method in interface org.infinispan.context.InvocationContext
Returns true if this call is performed in the context of an transaction, false otherwise.
isInvalidation() - Method in enum org.infinispan.config.Configuration.CacheMode
Returns true if the mode is invalidation, either sync or async.
isInvocationBatchingEnabled() - Method in class org.infinispan.config.Configuration
 
isKnownType(Class) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
isL1CacheEnabled() - Method in class org.infinispan.config.Configuration
 
isL1OnRehash() - Method in class org.infinispan.config.Configuration
 
isLast() - Method in class org.infinispan.config.CustomInterceptorConfig
 
isLocal(Object) - Method in interface org.infinispan.distribution.DistributionManager
 
isLocal(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
isLocalModeForced(InvocationContext) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
isLocked(LockManager, Fqn) - Static method in class org.infinispan.tree.TreeStructureSupport
 
isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Returns true if the cache entry is locked (either for reading or writing) by anyone, and false otherwise.
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
isLocked() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
isManagedResource() - Method in class org.infinispan.jmx.ResourceDMBean
 
isMarkedForRemoval(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Tests whether a given linked entry is marked for deletion.
isNull() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isNull() - Method in interface org.infinispan.container.entries.CacheEntry
Tests whether the entry represents a null value, typically used for repeatable read.
isNull() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isNull() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
IsolationLevel - Enum in org.infinispan.util.concurrent
Various transaction isolation levels as an enumerated class.
isOnePhaseCommit() - Method in class org.infinispan.commands.tx.PrepareCommand
 
isOnePhaseCommit() - Method in class org.infinispan.config.Configuration
 
isOperationRegistred(String) - Method in class org.infinispan.jmx.ResourceDMBean
 
isOriginLocal() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
isOriginLocal() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
isOriginLocal() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
isOriginLocal() - Method in interface org.infinispan.context.InvocationContext
Returns true if the call was originated locally, false if it is the result of a remote rpc.
isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
isOriginLocal() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
 
isPassivation() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
isPre() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
isPre() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
isPreload() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
isPreparing(Transaction) - Static method in class org.infinispan.context.impl.AbstractTxInvocationContext
Returns true if transaction is PREPARING, false otherwise
isPurgeOnStartup() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isPurgeOnStartup() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isPurgeSynchronously() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isPurgeSynchronously() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isPushStateWhenCoordinator() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
isPutIfAbsent() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isRemote() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
isRemoved() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isRemoved() - Method in interface org.infinispan.container.entries.CacheEntry
 
isRemoved() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isRemoved() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isReplayIgnoredRequests() - Method in class org.infinispan.remoting.responses.ExtendedResponse
 
isReplicated() - Method in enum org.infinispan.config.Configuration.CacheMode
 
isRoot() - Method in class org.infinispan.tree.Fqn
Returns true if this is a root Fqn.
isSameRM(XAResource) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
isSecure() - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
isShared() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
isShared() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isShared() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isShutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isSingletonStoreEnabled() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
isStateTransferEnabled() - Method in class org.infinispan.config.Configuration
 
isStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
isSuccessful() - Method in class org.infinispan.commands.write.ClearCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.PutMapCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.RemoveCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.ReplaceCommand
 
isSuccessful() - Method in interface org.infinispan.commands.write.WriteCommand
Some commands may want to provide information on whether the command was successful or not.
isSuccessful() - Method in class org.infinispan.remoting.responses.ExtendedResponse
 
isSuccessful() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
isSuccessful() - Method in interface org.infinispan.remoting.responses.Response
 
isSuccessful() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
isSuccessful() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
isSupportedType(Class) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultKey2StringMapper
Returns true if this is an primitive wrapper, false otherwise.
isSupportedType(Class) - Method in interface org.infinispan.loaders.jdbc.stringbased.Key2StringMapper
Do we support this key type?
isSupportStateTransfer() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
isSupportStateTransfer() - Method in interface org.infinispan.remoting.transport.Transport
Tests whether the transport supports state transfer
isSuspendTxAfterInvocation() - Method in class org.infinispan.batch.BatchContainer
 
isSyncCommitPhase() - Method in class org.infinispan.config.Configuration
 
isSynchronous() - Method in enum org.infinispan.config.Configuration.CacheMode
 
isSynchronous(InvocationContext) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
isSyncRollbackPhase() - Method in class org.infinispan.config.Configuration
 
isTerminated() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isTraceEnabled() - Method in class org.infinispan.util.logging.JDKLogImpl
 
isTraceEnabled() - Method in interface org.infinispan.util.logging.Log
 
isTraceEnabled() - Method in class org.infinispan.util.logging.Log4JLogImpl
 
isTransactionSuccessful() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
isTransactionSuccessful() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionCompletedEvent
 
isTypeExcluded(Class) - Static method in class org.infinispan.marshall.MarshalledValue
Tests whether the type should be excluded from MarshalledValue wrapping.
isUnsafeUnreliableReturnValues() - Method in class org.infinispan.config.Configuration
 
isUseAsyncMarshalling() - Method in class org.infinispan.config.Configuration
 
isUseEagerLocking() - Method in class org.infinispan.config.Configuration
 
isUseFutureReturnType() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
isUseFutureReturnType() - Method in interface org.infinispan.context.InvocationContext
 
isUseLazyDeserialization() - Method in class org.infinispan.config.Configuration
 
isUseLockStriping() - Method in class org.infinispan.config.Configuration
 
isUseReplQueue() - Method in class org.infinispan.config.Configuration
 
isUsingCacheLoaders() - Method in class org.infinispan.config.Configuration
 
isUsingPassivation() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isUsingPassivation() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isValid() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isValid() - Method in interface org.infinispan.container.entries.CacheEntry
 
isValid() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isValid() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isValid(Transaction) - Static method in class org.infinispan.context.impl.AbstractTxInvocationContext
Return s true of tx's status is ACTIVE or PREPARING
isValid() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
isValid() - Method in interface org.infinispan.remoting.responses.Response
 
isValid() - Method in class org.infinispan.remoting.responses.ValidResponse
 
isValid(Message) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
isValid() - Method in interface org.infinispan.tree.Node
Tests if a node reference is still valid.
isValid() - Method in class org.infinispan.tree.NodeImpl
 
isValidating() - Method in class org.infinispan.config.parsing.RootElementBuilder
 
isValidElementRoot(Element) - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
Tests whether the element passed in is a valid config element.
isValidRunningTx() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
isValidRunningTx() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns true if the current tx is either ACTIVE or PREPARING, false otherwise.
isWarnEnabled() - Method in class org.infinispan.util.logging.JDKLogImpl
 
isWarnEnabled() - Method in interface org.infinispan.util.logging.Log
 
isWarnEnabled() - Method in class org.infinispan.util.logging.Log4JLogImpl
 
isWriteSkewCheck() - Method in class org.infinispan.config.Configuration
 
iterator() - Method in class org.infinispan.container.FIFODataContainer
 
iterator() - Method in class org.infinispan.container.FIFODataContainer.KeySet
 
iterator() - Method in class org.infinispan.container.SimpleDataContainer
 
iterator() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
iterator() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer.KeySet
 
iterator() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
iterator() - Method in class org.infinispan.util.ImmutableListCopy
 
iterator() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns an iterator over the elements in this set.

J

JBossMarshaller - Class in org.infinispan.marshall.jboss
JBossMarshaller.
JBossMarshaller() - Constructor for class org.infinispan.marshall.jboss.JBossMarshaller
 
JBossStandaloneJTAManagerLookup - Class in org.infinispan.transaction.lookup
JTA standalone TM lookup.
JBossStandaloneJTAManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
JBossTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Uses JNDI to look-up the TransactionManager instance from "java:/TransactionManager".
JBossTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossTransactionManagerLookup
 
JCloudsBucket - Class in org.infinispan.loaders.s3.jclouds
A JClouds implementation of S3Bucket.
JCloudsBucket() - Constructor for class org.infinispan.loaders.s3.jclouds.JCloudsBucket
 
JCloudsConnection - Class in org.infinispan.loaders.s3.jclouds
An JClouds implementation of S3Connection.
JCloudsConnection() - Constructor for class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
JdbcBinaryCacheStore - Class in org.infinispan.loaders.jdbc.binary
BucketBasedCacheStore implementation that will store all the buckets as rows in database, each row coresponding to a bucket.
JdbcBinaryCacheStore() - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
JdbcBinaryCacheStoreConfig - Class in org.infinispan.loaders.jdbc.binary
Defines available configuration elements for JdbcBinaryCacheStore.
JdbcBinaryCacheStoreConfig(boolean) - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcBinaryCacheStoreConfig(ConnectionFactoryConfig, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcBinaryCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcMixedCacheStore - Class in org.infinispan.loaders.jdbc.mixed
Cache store that combines functionality of JdbcBinaryCacheStore and JdbcStringBasedCacheStore.
JdbcMixedCacheStore() - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
JdbcMixedCacheStoreConfig - Class in org.infinispan.loaders.jdbc.mixed
Configureation for JdbcMixedCacheStore.
JdbcMixedCacheStoreConfig(ConnectionFactoryConfig, TableManipulation, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
JdbcMixedCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
JdbcStringBasedCacheStore - Class in org.infinispan.loaders.jdbc.stringbased
CacheStore implementation that stores the entries in a database.
JdbcStringBasedCacheStore() - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
JdbcStringBasedCacheStoreConfig - Class in org.infinispan.loaders.jdbc.stringbased
Configuration for JdbcStringBasedCacheStore cache store.
JdbcStringBasedCacheStoreConfig(ConnectionFactoryConfig, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcStringBasedCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcStringBasedCacheStoreConfig(boolean) - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcUtil - Class in org.infinispan.loaders.jdbc
Contains common methods used by jdbc CacheStores.
JdbcUtil() - Constructor for class org.infinispan.loaders.jdbc.JdbcUtil
 
JdbmCacheStore - Class in org.infinispan.loaders.jdbm
A persistent CacheLoader based on the JDBM project.
JdbmCacheStore() - Constructor for class org.infinispan.loaders.jdbm.JdbmCacheStore
 
JdbmCacheStoreConfig - Class in org.infinispan.loaders.jdbm
Configures JdbmCacheStore.
JdbmCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
JdbmSerializer - Class in org.infinispan.loaders.jdbm
Uses the configured (runtime) Marshaller of the cache.
JdbmSerializer(Marshaller) - Constructor for class org.infinispan.loaders.jdbm.JdbmSerializer
Constructs a new JdbmSerializer.
JDKLogImpl - Class in org.infinispan.util.logging
Logger that delivers messages to a JDK logger
JDKLogImpl(String) - Constructor for class org.infinispan.util.logging.JDKLogImpl
 
JGroupsAddress - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups Address
JGroupsAddress() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
JGroupsAddress(Address) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
JGroupsAddressExternalizer - Class in org.infinispan.marshall.jboss.externalizers
JGroupsAddressExternalizer.
JGroupsAddressExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.JGroupsAddressExternalizer
 
JGroupsDistSync - Class in org.infinispan.remoting.transport.jgroups
A DistributedSync based on JGroups' FLUSH protocol
JGroupsDistSync() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
JGroupsResponseFilterAdapter - Class in org.infinispan.remoting.transport.jgroups
Acts as a bridge between JGroups RspFilter and ResponseFilter.
JGroupsResponseFilterAdapter(ResponseFilter) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
Creates an instance of the adapter
JGroupsStackParser - Class in org.infinispan.config.parsing
The purpose of this class is to parse the jgroups configuration from the config file into an compact string that can be passed as a config to the channel.
JGroupsStackParser() - Constructor for class org.infinispan.config.parsing.JGroupsStackParser
 
JGroupsTransport - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups transport
JGroupsTransport() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
JMX_RESOURCE_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
JmxDomainConflictException - Exception in org.infinispan.jmx
 
JmxDomainConflictException(String) - Constructor for exception org.infinispan.jmx.JmxDomainConflictException
 
JmxStatisticsExposer - Interface in org.infinispan.jmx
Interface containing common cache management operations
JmxStatsCommandInterceptor - Class in org.infinispan.interceptors.base
Base class for all the interceptors exposing management statistics.
JmxStatsCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 

K

key - Variable in class org.infinispan.commands.read.AbstractDataCommand
 
key - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
Key2StringMapper - Interface in org.infinispan.loaders.jdbc.stringbased
Defines the logic of mapping an key object to a String.
keySet() - Method in class org.infinispan.AbstractDelegatingCache
 
keySet() - Method in class org.infinispan.atomic.AtomicHashMap
 
keySet() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
keySet() - Method in class org.infinispan.CacheDelegate
 
keySet() - Method in interface org.infinispan.container.DataContainer
 
keySet() - Method in class org.infinispan.container.FIFODataContainer
 
keySet() - Method in class org.infinispan.container.SimpleDataContainer
 
keySet() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
keySet() - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
keySet() - Method in interface org.infinispan.loaders.s3.S3Bucket
 
keySet - Variable in class org.infinispan.util.AbstractMap
 
keySet() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
 
keySet() - Method in interface org.infinispan.util.BidirectionalMap
 
keySet() - Method in class org.infinispan.util.FastCopyHashMap
 
KnownComponentNames - Class in org.infinispan.factories
Holder for known named component names.
KnownComponentNames() - Constructor for class org.infinispan.factories.KnownComponentNames
 

L

lastIndexOf(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
Lifecycle - Interface in org.infinispan.lifecycle
Lifecycle interface that defines the lifecycle of components
linkAtEnd(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Links a new entry at the end of the linked list.
LinkedListExternalizer - Class in org.infinispan.marshall.jboss.externalizers
LinkedListExternalizer.
LinkedListExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.LinkedListExternalizer
 
Listenable - Interface in org.infinispan.notifications
Interface that denotes that the implementation can have listeners attached to it.
Listener - Annotation Type in org.infinispan.notifications
Class-level annotation used to annotate an object as being a valid cache listener.
listenersMap - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
listIterator() - Method in class org.infinispan.util.ImmutableListCopy
 
listIterator(int) - Method in class org.infinispan.util.ImmutableListCopy
 
load(Object) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Loads an entry mapped to by a given key. This implementation delegates to StoredMap.get(Object).
load(Object) - Method in interface org.infinispan.loaders.CacheLoader
Loads an entry mapped to by a given key.
load(Object) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
load(Object) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
load(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
load(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAll() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Loads all entries in the loader. This implementation returns a Set from StoredMap.values()
loadAll() - Method in interface org.infinispan.loaders.CacheLoader
Loads all entries in the loader.
loadAll() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAll() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAll() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAll() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
loadAll() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
loadAll() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.s3.S3CacheStore
 
loadBucket(String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Loads the bucket from the store, base on the hashcode.
loadBucket(String) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadBucket(File) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadBucket(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadBucket(String) - Method in class org.infinispan.loaders.s3.S3CacheStore
 
loadBucketContainingKey(String) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadClass(String) - Static method in class org.infinispan.util.Util
Loads the specified class using this class's classloader, or, if it is null (i.e.
loader - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
LoadersElementParser - Class in org.infinispan.config.parsing.element
Utility class for parsing the 'loaders' element in the .xml configuration file.
LoadersElementParser() - Constructor for class org.infinispan.config.parsing.element.LoadersElementParser
 
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Loads the bucket coresponding to the given key, and lookups the key within it.
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
LocalTxInvocationContext - Class in org.infinispan.context.impl
Invocation context to be used for locally originated transactions.
LocalTxInvocationContext() - Constructor for class org.infinispan.context.impl.LocalTxInvocationContext
 
locate(Object, int) - Method in interface org.infinispan.distribution.ConsistentHash
 
locate(Object, int) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
locate(Object) - Method in interface org.infinispan.distribution.DistributionManager
Locates a key in a cluster.
locate(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateAll(Collection<Object>, int) - Method in interface org.infinispan.distribution.ConsistentHash
 
locateAll(Collection<Object>, int) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
locateAll(Collection<Object>) - Method in interface org.infinispan.distribution.DistributionManager
Locates a list of keys in a cluster.
locateAll(Collection<Object>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
lock(K) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
lock(K) - Method in interface org.infinispan.AdvancedCache
Locks a given key eagerly across cache nodes in a cluster.
lock(Collection<? extends K>) - Method in interface org.infinispan.AdvancedCache
Locks collections of keys eagerly across cache nodes in a cluster.
lock(K) - Method in class org.infinispan.CacheDelegate
 
lock(Collection<? extends K>) - Method in class org.infinispan.CacheDelegate
 
lock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
lockAndRecord(Object, InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Acquires a lock of type lockType, on a specific entry in the cache.
lockAndRecord(Object, InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
LockContainer - Interface in org.infinispan.util.concurrent.locks.containers
A container for locks
LockControlCommand - Class in org.infinispan.commands
LockControlCommand is a command that enables distributed locking across infinispan nodes.
LockControlCommand() - Constructor for class org.infinispan.commands.LockControlCommand
 
LockControlCommand(Collection, String) - Constructor for class org.infinispan.commands.LockControlCommand
 
LockControlCommand(Collection, String, boolean) - Constructor for class org.infinispan.commands.LockControlCommand
 
lockForReading(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Acquires read lock on the given key.
lockForWriting(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Acquires write lock on the given key.
LockingInterceptor - Class in org.infinispan.interceptors
Interceptor to implement MVCC functionality.
LockingInterceptor() - Constructor for class org.infinispan.interceptors.LockingInterceptor
 
lockInterruptibly() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
LockManager - Interface in org.infinispan.util.concurrent.locks
An interface to deal with all aspects of acquiring and releasing locks for cache entries.
LockManagerFactory - Class in org.infinispan.factories
// TODO: MANIK: Document this
LockManagerFactory() - Constructor for class org.infinispan.factories.LockManagerFactory
 
LockManagerImpl - Class in org.infinispan.util.concurrent.locks
Handles locks for the MVCC based LockingInterceptor
LockManagerImpl() - Constructor for class org.infinispan.util.concurrent.locks.LockManagerImpl
 
locks - Variable in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
LockSupportCacheStore - Class in org.infinispan.loaders
This class extends AbstractCacheStore adding lock support for consistently acceessing stored data.
LockSupportCacheStore() - Constructor for class org.infinispan.loaders.LockSupportCacheStore
 
LockSupportCacheStoreConfig - Class in org.infinispan.loaders
Adds configuration support for LockSupportCacheStore.
LockSupportCacheStoreConfig() - Constructor for class org.infinispan.loaders.LockSupportCacheStoreConfig
 
log - Variable in class org.infinispan.config.AbstractConfigurationBean
 
log - Variable in class org.infinispan.factories.AbstractComponentFactory
 
log - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
log - Variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
log - Static variable in class org.infinispan.transaction.tm.DummyTransactionManager
 
Log - Interface in org.infinispan.util.logging
Infinispan's log abstraction layer.
Log4JLogImpl - Class in org.infinispan.util.logging
Logger that delivers messages to a Log4J logger
Log4JLogImpl(String) - Constructor for class org.infinispan.util.logging.Log4JLogImpl
 
logAndThrow(Exception, String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
logAndThrow(Exception, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
logCommit(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionLog
 
LogFactory - Class in org.infinispan.util.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.util.logging.LogFactory
 
logNoTxWrite(WriteCommand) - Method in class org.infinispan.transaction.TransactionLog
 
logOnePhaseCommit(GlobalTransaction, WriteCommand[]) - Method in class org.infinispan.transaction.TransactionLog
 
logPrepare(PrepareCommand) - Method in class org.infinispan.transaction.TransactionLog
 
lookedUpEntries - Variable in class org.infinispan.context.impl.NonTxInvocationContext
 
lookupComponent(Class, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
lookupComponent(Class, String) - Method in class org.infinispan.factories.ComponentRegistry
 
lookupEntry(Object) - Method in interface org.infinispan.context.EntryLookup
Retrieves an entry from the collection of looked up entries in the current scope.
lookupEntry(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
lookupEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
lookupEntry(Object) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
lookupEntry(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
lookupFile(String) - Method in class org.infinispan.util.FileLookup
Looks up the file, see : FileLookup.
lookupFileLocation(String) - Method in class org.infinispan.util.FileLookup
 
lookupLocalComponent(Class, String) - Method in class org.infinispan.factories.ComponentRegistry
 
lookupMvccEntry(InvocationContext, Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
LRUDataContainer - Class in org.infinispan.container
Based on the same techniques outlined in the FIFODataContainer, this implementation additionally unlinks and re-links entries at the tail whenever entries are visited (using a get()) or are updated (a put() on an existing key).
LRUDataContainer() - Constructor for class org.infinispan.container.LRUDataContainer
 

M

MAGICNUMBER_ARRAY - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ARRAY_LIST - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_BOOLEAN - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_BYTE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_CACHESTORE_BUCKET - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_CHAR - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_COMMAND - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_DOUBLE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_EXCEPTION_RESPONSE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_EXTENDED_RESPONSE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_FASTCOPY_HASHMAP - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_FLOAT - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_GTX - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_HASH_MAP - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_HASH_SET - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICE_IMMORTAL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICE_MORTAL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICE_TRANSIENT - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICE_TRANSIENT_MORTAL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICV_IMMORTAL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICV_MORTAL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICV_TRANSIENT - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_ICV_TRANSIENT_MORTAL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_IMMUTABLE_MAPCOPY - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_INTEGER - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_JG_ADDRESS - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_LINKED_LIST - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_LONG - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_MARSHALLEDVALUE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_NULL - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_OBJECT - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_REF - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_REQUEST_IGNORED_RESPONSE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_SERIALIZABLE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_SHORT - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_SINGLETON_LIST - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_STRING - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_SUCCESSFUL_RESPONSE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_TRANSACTION_LOG - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_TREE_MAP - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_TREE_SET - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MAGICNUMBER_UNSUCCESSFUL_RESPONSE - Static variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
main(String[]) - Static method in class org.infinispan.config.parsing.ConfigFilesConvertor
usage : java org.jboss.cache.config.parsing.ConfigFilesConvertor -Dsource=config-2.x.xml -Ddestination=config-3.x.xnl
main(String[]) - Static method in class org.infinispan.demo.InfinispanDemo
 
main(String[]) - Static method in class org.infinispan.Version
Prints version information.
ManagedAttribute - Annotation Type in org.infinispan.jmx.annotations
Indicates that a public method or a field (any visibility) in an MBean class defines an MBean attribute.
ManagedOperation - Annotation Type in org.infinispan.jmx.annotations
Indicates that a method in an MBean class defines an MBean operation.
MANAGER_OBJECT - Static variable in class org.infinispan.jopr.infinispan.InfinispanDiscovery
 
map - Variable in class org.infinispan.util.concurrent.ConcurrentHashSet
 
MapExternalizer - Class in org.infinispan.marshall.jboss.externalizers
Map externalizer for all map implementations except immutable maps and singleton maps, i.e.
MapExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.MapExternalizer
 
markNextReference(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Places a removal marker the 'next' reference on the given entry.
markPrevReference(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Places a removal marker the 'previous' reference on the given entry.
marshall(Marshaller, Object) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
marshallArray(Object, ObjectOutput, Map<Object, Integer>) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
marshallCollection(Collection, ObjectOutput) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
 
MarshalledValue - Class in org.infinispan.marshall
Wrapper that wraps cached data, providing lazy deserialization using the calling thread's context class loader.
MarshalledValue(Object, boolean) - Constructor for class org.infinispan.marshall.MarshalledValue
 
MarshalledValue() - Constructor for class org.infinispan.marshall.MarshalledValue
 
MarshalledValue(byte[], int) - Constructor for class org.infinispan.marshall.MarshalledValue
 
MarshalledValueExternalizer - Class in org.infinispan.marshall.jboss.externalizers
MarshalledValueExternalizer.
MarshalledValueExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.MarshalledValueExternalizer
 
MarshalledValueInterceptor - Class in org.infinispan.interceptors
Interceptor that handles the wrapping and unwrapping of cached data using MarshalledValues.
MarshalledValueInterceptor() - Constructor for class org.infinispan.interceptors.MarshalledValueInterceptor
 
marshaller - Variable in class org.infinispan.CacheDelegate
 
marshaller - Variable in class org.infinispan.loaders.AbstractCacheStore
 
marshaller - Variable in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
Marshaller - Interface in org.infinispan.marshall
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
MarshallerAdapter - Class in org.infinispan.remoting.transport.jgroups
Bridge between JGroups and Infinispan marshallers
MarshallerAdapter(Marshaller) - Constructor for class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
MarshallerFactory - Class in org.infinispan.factories
MarshallerFactory.
MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
 
MarshallerImpl - Class in org.infinispan.marshall
Deprecated. JBoss Marshaller based Marshaller is now use rather than this legacy home grown marshaller. This marshaller hasn't been removed yet so that we can can carry on comparing payload sizes between the different marshallers. This will specially help as JBoss Marshaller continues to provide more and more efficient payloads.
MarshallerImpl() - Constructor for class org.infinispan.marshall.MarshallerImpl
Deprecated.  
marshallMap(Map, ObjectOutput) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
 
marshallObject(Object, ObjectOutput, Map<Object, Integer>) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
marshallString(String, ObjectOutput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
MarshallUtil - Class in org.infinispan.marshall.jboss
MarshallUtil.
MarshallUtil() - Constructor for class org.infinispan.marshall.jboss.MarshallUtil
 
MBean - Annotation Type in org.infinispan.jmx.annotations
Classes anotaded with this will be exposed as MBeans.
MBeanServerLookup - Interface in org.infinispan.jmx
Implementors of this should return an MBeanServer to which MBeans will be registered.
merge(DeltaAware) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
merge(DeltaAware) - Method in interface org.infinispan.atomic.Delta
Merge the current set of deltas with a given DeltaAware instance, and return a coherent and complete DeltaAware instance.
merge(DeltaAware) - Method in class org.infinispan.atomic.NullDelta
 
method - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
Modification - Interface in org.infinispan.loaders.modifications
An interface that defines a CacheStore modification
Modification.Type - Enum in org.infinispan.loaders.modifications
 
modifications - Variable in class org.infinispan.commands.tx.PrepareCommand
 
ModificationsTransactionWorker - Class in org.infinispan.loaders.bdbje
Adapter that allows a list of Modifications to be performed atomically via TransactionRunner.
ModificationsTransactionWorker(CacheStore, List<? extends Modification>) - Constructor for class org.infinispan.loaders.bdbje.ModificationsTransactionWorker
Associates Modifications that will be applied to the supplied CacheStore
modifiedEntries - Variable in class org.infinispan.util.Util.MapModifications
 
MortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is mortal.
MortalCacheEntryExternalizer - Class in org.infinispan.marshall.jboss.externalizers
MortalCacheEntryExternalizer.
MortalCacheEntryExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.MortalCacheEntryExternalizer
 
MortalCacheValue - Class in org.infinispan.container.entries
A mortal cache value, to correspond with MortalCacheEntry
MortalCacheValueExternalizer - Class in org.infinispan.marshall.jboss.externalizers
MortalCacheValueExternalizer.
MortalCacheValueExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.MortalCacheValueExternalizer
 
move(Fqn, Fqn) - Method in interface org.infinispan.tree.TreeCache
Moves a part of the cache to a different subtree.
move(Fqn, Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
move(String, String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes in string representations of Fqns.
move(String, String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
move(Fqn, Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(Fqn, Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(String, String) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(String, String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
MultipleRpcCommand - Class in org.infinispan.commands.remote
Command that implements cluster replication logic.
MultipleRpcCommand(List<ReplicableCommand>, String) - Constructor for class org.infinispan.commands.remote.MultipleRpcCommand
 
MultipleRpcCommand() - Constructor for class org.infinispan.commands.remote.MultipleRpcCommand
 
MVCCEntry - Interface in org.infinispan.container.entries
An entry that can be safely copied when updates are made, to provide MVCC semantics

N

NamedCacheNotFoundException - Exception in org.infinispan.manager
Thrown when a named cache cannot be found.
NamedCacheNotFoundException() - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedComponentFactory - Class in org.infinispan.factories
A specialized type of component factory that knows how to create named components, identified with the ComponentName annotation on the classes requested in Inject annotated methods.
NamedComponentFactory() - Constructor for class org.infinispan.factories.NamedComponentFactory
 
NamedExecutorsFactory - Class in org.infinispan.factories
A factory that specifically knows how to create named executors.
NamedExecutorsFactory() - Constructor for class org.infinispan.factories.NamedExecutorsFactory
 
NaturalComparator - Class in org.infinispan.loaders.jdbm
Compares keys using their natural ordering.
NaturalComparator() - Constructor for class org.infinispan.loaders.jdbm.NaturalComparator
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
needMoreResponses() - Method in interface org.infinispan.remoting.rpc.ResponseFilter
Right after calling ResponseFilter.isAcceptable(Response, Address), this method is called to see whether we are done with the request and can unblock the caller
needMoreResponses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
 
needToDestroyFailedCache() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
needToInitializeBeforeStart() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
newCondition() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
newFixedThreadPool(int, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue.
newFixedThreadPool(int, ThreadFactory, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue, using the provided ThreadFactory to create new threads when needed.
newInstance(Cache, Object) - Static method in class org.infinispan.atomic.AtomicHashMap
Construction only allowed through this factory method.
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
next() - Method in class org.infinispan.container.FIFODataContainer.KeyIterator
 
next() - Method in class org.infinispan.container.FIFODataContainer.ValueIterator
 
next() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer.KeyIterator
 
next() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer.ValueIterator
 
Node<K,V> - Interface in org.infinispan.tree
A Node is a named logical grouping of data in the TreeCache API of JBoss Cache.
NodeImpl<K,V> - Class in org.infinispan.tree
Implementation backed by an AtomicMap
NodeImpl(Fqn, Cache, BatchContainer, InvocationContextContainer) - Constructor for class org.infinispan.tree.NodeImpl
 
NodeKey - Class in org.infinispan.tree
A class that represents the key to a node
NodeKey(Fqn, NodeKey.Type) - Constructor for class org.infinispan.tree.NodeKey
 
NodeKey.Type - Enum in org.infinispan.tree
 
NodeNotExistsException - Exception in org.infinispan.tree
Thrown when an operation is attempted on a non-existing node in the cache
NodeNotExistsException() - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotExistsException(String) - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotExistsException(String, Throwable) - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotValidException - Exception in org.infinispan.tree
Thrown whenever operations are attempted on a node that is no longer valid.
NodeNotValidException() - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(Throwable) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(String) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(String, Throwable) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NonTxInvocationContext - Class in org.infinispan.context.impl
Context to be used for non transactional calls, both remote and local.
NonTxInvocationContext() - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NonVolatile - Annotation Type in org.infinispan.factories.annotations
This annotation is used for components that will be registered in the ComponentRegistry, that are resilient to changes in configuration.
NotificationInterceptor - Class in org.infinispan.interceptors
The interceptor in charge of firing off notifications to cache listeners
NotificationInterceptor() - Constructor for class org.infinispan.interceptors.NotificationInterceptor
 
notifier - Variable in class org.infinispan.CacheDelegate
 
notifier - Variable in class org.infinispan.commands.tx.PrepareCommand
 
notifier - Variable in class org.infinispan.commands.write.RemoveCommand
 
notifier - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.EvictCommand
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.InvalidateCommand
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.RemoveCommand
 
notifyAfterCompletion(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
notifyBeforeCompletion() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
notifyCacheEntryActivated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryActivated event.
notifyCacheEntryActivated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryCreated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryCreated event.
notifyCacheEntryCreated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryEvicted(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryEvicted event.
notifyCacheEntryEvicted(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryInvalidated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryInvalidated event.
notifyCacheEntryInvalidated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryLoaded(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryLoaded event.
notifyCacheEntryLoaded(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryModified(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryModified event.
notifyCacheEntryModified(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryPassivated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryPassivated event.
notifyCacheEntryPassivated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryRemoved(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryRemoved event.
notifyCacheEntryRemoved(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryVisited(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryVisited event.
notifyCacheEntryVisited(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheStarted(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyCacheStarted(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyCacheStopped(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyCacheStopped(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
notifyDone() - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
NotifyingFuture<T> - Interface in org.infinispan.util.concurrent
A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified of when the future completes.
NotifyingFutureImpl - Class in org.infinispan.util.concurrent
Constructs an instance of a NotifyingFuture.
NotifyingFutureImpl(Object) - Constructor for class org.infinispan.util.concurrent.NotifyingFutureImpl
 
NotifyingNotifiableFuture<Object> - Interface in org.infinispan.util.concurrent
An internal interface which adds the ability to inform the future of completion.
notifyStateReceiptFailed(StateTransferException) - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
notifyStateReceiptSucceeded() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction completion event.
notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyTransactionRegistered(GlobalTransaction, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction registration event.
notifyTransactionRegistered(GlobalTransaction, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyViewChange(List<Address>, Address) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
Notifies all registered listeners of a viewChange event.
notifyViewChange(List<Address>, Address) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
NULL_COMPONENT - Static variable in class org.infinispan.factories.AbstractComponentRegistry
 
NullDelta - Class in org.infinispan.atomic
Represents no changes.
NullDelta() - Constructor for class org.infinispan.atomic.NullDelta
 
NullMarkerEntry - Class in org.infinispan.container.entries
A marker entry to represent a null for repeatable read, so that a read that returns a null can continue to return null.
NullMarkerEntryForRemoval - Class in org.infinispan.container.entries
A null entry that is read in for removal
NullMarkerEntryForRemoval(Object) - Constructor for class org.infinispan.container.entries.NullMarkerEntryForRemoval
 

O

ObjectDuplicator - Class in org.infinispan.util
A helper that efficiently duplicates known object types.
ObjectDuplicator() - Constructor for class org.infinispan.util.ObjectDuplicator
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in interface org.infinispan.marshall.Marshaller
 
objectFromByteBuffer(byte[]) - Method in interface org.infinispan.marshall.Marshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectFromInputStream(InputStream) - Method in interface org.infinispan.marshall.Marshaller
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.marshall.Marshaller
Unmarshalls an object from an ObjectInput
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectToBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
A method that returns an instance of ByteBuffer, which allows direct access to the byte array with minimal array copying
objectToBuffer(Object) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
objectToBuffer(Object) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectToByteBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.marshall.Marshaller
Marshalls an object to a given ObjectOutput
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
oldValue - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
onePhaseCommit - Variable in class org.infinispan.commands.tx.PrepareCommand
 
open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
Operation<K,V> - Class in org.infinispan.atomic
 
Operation() - Constructor for class org.infinispan.atomic.Operation
 
org.infinispan - package org.infinispan
This is the core of Infinispan, a distributed, transactional, highly scalable data grid platform.
org.infinispan.atomic - package org.infinispan.atomic
This package contains the AtomicMap interfaces and API that Infinispan exposes as building blocks in creating other public interface such as the tree API.
org.infinispan.batch - package org.infinispan.batch
Support for batching calls using the Cache.startBatch() and Cache.endBatch(boolean) API.
org.infinispan.commands - package org.infinispan.commands
Commands that operate on the cache, either locally or remotely.
org.infinispan.commands.control - package org.infinispan.commands.control
 
org.infinispan.commands.read - package org.infinispan.commands.read
 
org.infinispan.commands.remote - package org.infinispan.commands.remote
 
org.infinispan.commands.tx - package org.infinispan.commands.tx
 
org.infinispan.commands.write - package org.infinispan.commands.write
 
org.infinispan.config - package org.infinispan.config
Cache configuration beans and parsers.
org.infinispan.config.parsing - package org.infinispan.config.parsing
 
org.infinispan.config.parsing.element - package org.infinispan.config.parsing.element
 
org.infinispan.container - package org.infinispan.container
Data containers which store cache entries.
org.infinispan.container.entries - package org.infinispan.container.entries
 
org.infinispan.context - package org.infinispan.context
Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags.
org.infinispan.context.impl - package org.infinispan.context.impl
 
org.infinispan.demo - package org.infinispan.demo
 
org.infinispan.distribution - package org.infinispan.distribution
Classes relating to the distributed cache mode.
org.infinispan.eviction - package org.infinispan.eviction
Classes related to eviction.
org.infinispan.executors - package org.infinispan.executors
Implementations of different executors used for asynchronous operation.
org.infinispan.factories - package org.infinispan.factories
Factories are internal components used to create other components based on a cache's configuration.
org.infinispan.factories.annotations - package org.infinispan.factories.annotations
 
org.infinispan.factories.scopes - package org.infinispan.factories.scopes
 
org.infinispan.interceptors - package org.infinispan.interceptors
Infinispan is designed around a set of interceptors around a data container.
org.infinispan.interceptors.base - package org.infinispan.interceptors.base
 
org.infinispan.io - package org.infinispan.io
 
org.infinispan.jmx - package org.infinispan.jmx
Helpers that allow easy exposure of attributes and operations via JMX.
org.infinispan.jmx.annotations - package org.infinispan.jmx.annotations
 
org.infinispan.jopr.infinispan - package org.infinispan.jopr.infinispan
 
org.infinispan.lifecycle - package org.infinispan.lifecycle
Component lifecycle.
org.infinispan.loaders - package org.infinispan.loaders
This package contains loaders and stores, which are used for overflow or persistence.
org.infinispan.loaders.bdbje - package org.infinispan.loaders.bdbje
This package contains a CacheStore implementation based on Oracle's BDBJE storage engine.
org.infinispan.loaders.bucket - package org.infinispan.loaders.bucket
 
org.infinispan.loaders.cluster - package org.infinispan.loaders.cluster
 
org.infinispan.loaders.decorators - package org.infinispan.loaders.decorators
 
org.infinispan.loaders.file - package org.infinispan.loaders.file
 
org.infinispan.loaders.jdbc - package org.infinispan.loaders.jdbc
This package contains a CacheStore implementation based on a JDBC database connection.
org.infinispan.loaders.jdbc.binary - package org.infinispan.loaders.jdbc.binary
This JDBC CacheStore implementation is optimized for storing binary (non-String) keys in the cache.
org.infinispan.loaders.jdbc.connectionfactory - package org.infinispan.loaders.jdbc.connectionfactory
Connection factories for use with the JDBC Cache Store.
org.infinispan.loaders.jdbc.mixed - package org.infinispan.loaders.jdbc.mixed
This is a delegating CacheStore implementation that delegates either to a binary or String based JDBC cache store depending on the key used.
org.infinispan.loaders.jdbc.stringbased - package org.infinispan.loaders.jdbc.stringbased
This JDBC CacheStore implementation is optimized for storing String keys in the cache.
org.infinispan.loaders.jdbm - package org.infinispan.loaders.jdbm
This package contains a CacheStore implementation based on persisting to JDBM.
org.infinispan.loaders.modifications - package org.infinispan.loaders.modifications
 
org.infinispan.loaders.s3 - package org.infinispan.loaders.s3
This package contains a CacheStore implementation based on persisting to Amazon's S3 service.
org.infinispan.loaders.s3.jclouds - package org.infinispan.loaders.s3.jclouds
A bridge between Infinispan and JClouds - a fast S3 communication library.
org.infinispan.manager - package org.infinispan.manager
Cache manager package
org.infinispan.marshall - package org.infinispan.marshall
Infinispan makes use of custom marshalling to serialize and deserialize state wherever possible, rather than falling back to the JDK to do this.
org.infinispan.marshall.jboss - package org.infinispan.marshall.jboss
 
org.infinispan.marshall.jboss.externalizers - package org.infinispan.marshall.jboss.externalizers
 
org.infinispan.notifications - package org.infinispan.notifications
Notifications and eventing for listeners on both the Cache and CacheManager interfaces.
org.infinispan.notifications.cachelistener - package org.infinispan.notifications.cachelistener
 
org.infinispan.notifications.cachelistener.annotation - package org.infinispan.notifications.cachelistener.annotation
 
org.infinispan.notifications.cachelistener.event - package org.infinispan.notifications.cachelistener.event
 
org.infinispan.notifications.cachemanagerlistener - package org.infinispan.notifications.cachemanagerlistener
 
org.infinispan.notifications.cachemanagerlistener.annotation - package org.infinispan.notifications.cachemanagerlistener.annotation
 
org.infinispan.notifications.cachemanagerlistener.event - package org.infinispan.notifications.cachemanagerlistener.event
 
org.infinispan.remoting - package org.infinispan.remoting
Remote communication between cache instances.
org.infinispan.remoting.responses - package org.infinispan.remoting.responses
 
org.infinispan.remoting.rpc - package org.infinispan.remoting.rpc
 
org.infinispan.remoting.transport - package org.infinispan.remoting.transport
 
org.infinispan.remoting.transport.jgroups - package org.infinispan.remoting.transport.jgroups
 
org.infinispan.statetransfer - package org.infinispan.statetransfer
Transfer of state to new caches in a cluster.
org.infinispan.transaction - package org.infinispan.transaction
JTA transaction support.
org.infinispan.transaction.lookup - package org.infinispan.transaction.lookup
 
org.infinispan.transaction.tm - package org.infinispan.transaction.tm
 
org.infinispan.transaction.xa - package org.infinispan.transaction.xa
 
org.infinispan.tree - package org.infinispan.tree
This package contains the TreeCache.
org.infinispan.util - package org.infinispan.util
 
org.infinispan.util.concurrent - package org.infinispan.util.concurrent
 
org.infinispan.util.concurrent.locks - package org.infinispan.util.concurrent.locks
 
org.infinispan.util.concurrent.locks.containers - package org.infinispan.util.concurrent.locks.containers
 
org.infinispan.util.logging - package org.infinispan.util.logging
 
overriddenConfigurationElements - Variable in class org.infinispan.config.AbstractConfigurationBean
 
OwnableReentrantLock - Class in org.infinispan.util.concurrent.locks
A lock that supports reentrancy based on owner (and not on current thread).
OwnableReentrantLock(InvocationContextContainer) - Constructor for class org.infinispan.util.concurrent.locks.OwnableReentrantLock
Creates a new lock instance.
OwnableReentrantPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A per-entry lock container for OwnableReentrantLocks
OwnableReentrantPerEntryLockContainer(int, InvocationContextContainer) - Constructor for class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
OwnableReentrantStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A LockContainer that holds OwnableReentrantLocks.
OwnableReentrantStripedLockContainer(int, InvocationContextContainer) - Constructor for class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
Creates a new LockContainer which uses a certain number of shared locks across all elements that need to be locked.
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
Tests if a give owner owns a lock on a specified object.
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Tests whether a given owner owns a lock of lockType on a particular cache entry.
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 

P

parse(InputStream, OutputStream, String) - Method in class org.infinispan.config.parsing.ConfigFilesConvertor
 
parse(String, OutputStream, String) - Method in class org.infinispan.config.parsing.ConfigFilesConvertor
Writes to the os the infinispan 4.x configuration file resulted by transforming configuration file passed in as inputFile.
parseAsyncStoreConfig(Element) - Method in class org.infinispan.config.parsing.element.LoadersElementParser
 
parseClusterConfigXml(Element) - Method in class org.infinispan.config.parsing.JGroupsStackParser
Parses the cluster config which is used to start a JGroups channel
parseCustomInterceptors(Element) - Method in class org.infinispan.config.parsing.element.CustomInterceptorsElementParser
Iterates within the given element looking for custom interceptors.
ParsedAttributes - Class in org.infinispan.config.parsing
Helper class for holding attributes defined in configuration file.
parseDefaultConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses the default template configuration.
parseDefaultConfiguration() - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
 
parseGlobalConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
GlobalConfiguration would also have a reference to the template default configuration, accessible via GlobalConfiguration.getDefaultConfiguration()

This is typically used to configure a DefaultCacheManager

parseGlobalConfiguration() - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
 
parseLoadersElement(Element) - Method in class org.infinispan.config.parsing.element.LoadersElementParser
 
parseNamedConfigurations() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses and retrieves configuration overrides for named caches.
parseNamedConfigurations() - Method in class org.infinispan.config.parsing.XmlConfigurationParserImpl
 
parseSingletonStoreConfig(Element) - Method in class org.infinispan.config.parsing.element.LoadersElementParser
 
PassivationInterceptor - Class in org.infinispan.interceptors
Writes evicted entries back to the store on the way in through the CacheStore
PassivationInterceptor() - Constructor for class org.infinispan.interceptors.PassivationInterceptor
 
peekElements() - Method in class org.infinispan.tree.Fqn
Peeks into the elements that build up this Fqn.
perform(InvocationContext) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.LockControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.SizeCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
Invokes a logical "get(key)" on a remote cache and returns results.
perform(InvocationContext) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
Executes commands replicated to the current cache instance by other cache instances.
perform(InvocationContext) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
perform(InvocationContext) - Method in interface org.infinispan.commands.ReplicableCommand
Performs the primary function of the command.
perform(InvocationContext) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.tx.PrepareCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ClearCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.EvictCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateCommand
Performs an invalidation on a specified entry
perform(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.PutMapCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.RemoveCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ReplaceCommand
 
PlatformMBeanServerLookup - Class in org.infinispan.jmx
Default implementation for MBeanServerLookup, will return the platform MBean server.
PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
 
PluggableConfigurationComponent - Class in org.infinispan.config
A configuration component where the implementation class can be specified, and comes with its own set of properties.
PluggableConfigurationComponent() - Constructor for class org.infinispan.config.PluggableConfigurationComponent
 
PooledConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Pooled connection factory based on C3P0.
PooledConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
possiblyLocked(CacheEntry) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Inspects the entry for signs that it is possibly locked, and hence would need to be unlocked.
possiblyLocked(CacheEntry) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
preload() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
preload() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
Performs a preload on the cache based on the cache loader preload configs used when configuring the cache.
PreparableTransactionRunner - Class in org.infinispan.loaders.bdbje
Adapted version of TransactionRunner, which allows us to prepare a transaction without committing it.

The transaction prepared is accessible via CurrentTransaction.getTransaction()

PreparableTransactionRunner(Environment, int, TransactionConfig) - Constructor for class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Delegates to the superclass and caches a current reference to CurrentTransaction.
PreparableTransactionRunner(Environment) - Constructor for class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Delegates to the superclass and caches a current reference to CurrentTransaction.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.AbstractCacheStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Issues a prepare call with a set of modifications to be applied to the cache store delegates to BdbjeCacheStore.applyModifications(java.util.List), if isOnePhase.
prepare(List<? extends Modification>, GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Looks up the SleepyCat transaction associated with tx.
prepare(TransactionWorker) - Method in class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Same behaviour as run, except that the transaction is not committed on success.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in interface org.infinispan.loaders.CacheStore
Issues a prepare call with a set of modifications to be applied to the cache store
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
prepare(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
PrepareCommand - Class in org.infinispan.commands.tx
// TODO: MANIK: Document this
PrepareCommand(GlobalTransaction, boolean, WriteCommand...) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand() - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
prepareRenderer(TableCellRenderer, int, int) - Method in class org.infinispan.demo.InfinispanDemo.AlternateColorTable
Shades alternate rows in different colors.
PrePostProcessingCommandInterceptor - Class in org.infinispan.interceptors.base
This interceptor adds pre and post processing to each visitXXX() method.
PrePostProcessingCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
prettyPrintTime(long) - Static method in class org.infinispan.util.Util
Prints a time for display
printDebugStats() - Method in class org.infinispan.util.FastCopyHashMap
 
printLicense() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
prints terms of use for Berkeley DB JE
printLockInfo() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Prints lock information for all locks.
printLockInfo() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
printTree(TreeCache<?, ?>, boolean) - Static method in class org.infinispan.tree.TreeStructureSupport
Visual representation of a tree
printVersion() - Static method in class org.infinispan.Version
Returns version information as a string.
printVersionId(byte[], int) - Static method in class org.infinispan.Version
 
printVersionId(byte[]) - Static method in class org.infinispan.Version
 
processEviction() - Method in interface org.infinispan.eviction.EvictionManager
Processes the eviction event queue.
processEviction() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
processVisitableCommand(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
projectName - Static variable in class org.infinispan.Version
 
properties - Variable in class org.infinispan.config.PluggableConfigurationComponent
 
purge() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
purge() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
purgeExpired() - Method in interface org.infinispan.container.DataContainer
Purges entries that have passed their expiry time
purgeExpired() - Method in class org.infinispan.container.FIFODataContainer
 
purgeExpired() - Method in class org.infinispan.container.SimpleDataContainer
 
purgeExpired() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
purgeExpired() - Method in class org.infinispan.loaders.AbstractCacheStore
 
purgeExpired() - Method in interface org.infinispan.loaders.CacheStore
Purges expired entries from the store.
purgeExpired() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
PurgeExpired - Class in org.infinispan.loaders.modifications
 
PurgeExpired() - Constructor for class org.infinispan.loaders.modifications.PurgeExpired
 
purgeIfNecessary() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.AbstractCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Iterate through StoredMap.entrySet() and remove, if expired.
purgeInternal() - Method in class org.infinispan.loaders.file.FileCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Purge expired entries.
purgeInternal() - Method in class org.infinispan.loaders.s3.S3CacheStore
 
pushState(Cache) - Method in class org.infinispan.loaders.decorators.SingletonStore
Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
put(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
put(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
put(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
put(K, V) - Method in class org.infinispan.atomic.AtomicHashMap
 
put(K, V) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
put(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.put(Object, Object), which takes in lifespan parameters.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.put(Object, Object), which takes in lifespan parameters.
put(K, V) - Method in class org.infinispan.CacheDelegate
 
put(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
put(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
put(Object, Object, long, long) - Method in interface org.infinispan.container.DataContainer
Puts an entry in the cache along with a lifespan and a maxIdle time
put(Object, Object, long, long) - Method in class org.infinispan.container.FIFODataContainer
 
put(Object, Object, long, long) - Method in class org.infinispan.container.LRUDataContainer
 
put(Object, Object, long, long) - Method in class org.infinispan.container.SimpleDataContainer
 
put(Object, Object, long, long) - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
put(K, V) - Method in interface org.infinispan.tree.Node
Associates the specified value with the specified key for this node.
put(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
put(K, V) - Method in class org.infinispan.tree.NodeImpl
 
put(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
put(Fqn, K, V) - Method in interface org.infinispan.tree.TreeCache
Associates the specified value with the specified key for a Node in this cache.
put(Fqn, K, V, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, K, V) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
put(String, K, V, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(Fqn, Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.TreeCache
Copies all of the mappings from the specified map to a Node.
put(Fqn, Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
put(String, Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, K, V) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, K, V, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, K, V) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, K, V, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(K, V) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Associates the specified value with the specified key in this map.
put(K, V) - Method in class org.infinispan.util.FastCopyHashMap
 
putAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.AtomicHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.putAll(Map), which takes in lifespan parameters.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.putAll(Map), which takes in lifespan parameters.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheDelegate
 
putAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.CacheDelegate
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.Node
Copies all of the mappings from the specified map to this node's map.
putAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.Node
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.NodeImpl
 
putAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Copies all of the mappings from the specified map to this map.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.FastCopyHashMap
 
putAllAsync(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.Cache
Asynchronous version of Map.putAll(Map).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putAll(Map, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putAll(Map, long, TimeUnit, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.CacheDelegate
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheDelegate
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAsync(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putAsync(K, V) - Method in interface org.infinispan.Cache
Asynchronous version of Map.put(Object, Object).
putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.put(Object, Object, long, TimeUnit) .
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.put(Object, Object, long, TimeUnit, long, TimeUnit).
putAsync(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
putAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
putAsync(K, V) - Method in class org.infinispan.CacheDelegate
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putForExternalRead(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putForExternalRead(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putForExternalRead(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putForExternalRead(K, V) - Method in interface org.infinispan.Cache
Under special operating behavior, associates the value with the specified key.
putForExternalRead(K, V) - Method in class org.infinispan.CacheDelegate
 
putForExternalRead(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V) - Method in interface org.infinispan.tree.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, Flag...) - Method in interface org.infinispan.tree.Node
 
putIfAbsent(K, V) - Method in class org.infinispan.tree.NodeImpl
 
putIfAbsent(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
putIfAbsentAsync(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
putIfAbsentAsync(K, V) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.putIfAbsent(Object, Object).
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putIfAbsent(Object, Object, long, TimeUnit) .
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit).
putIfAbsentAsync(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.CacheDelegate
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
PutKeyValueCommand - Class in org.infinispan.commands.write
Implements functionality defined by Map.put(Object, Object)
PutKeyValueCommand() - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
PutKeyValueCommand(Object, Object, boolean, CacheNotifier, long, long) - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.context.EntryLookup
Puts an entry in the registry of looked up entries in the current scope.
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
PutMapCommand - Class in org.infinispan.commands.write
 
PutMapCommand() - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutMapCommand(Map, CacheNotifier, long, long) - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutOperation<K,V> - Class in org.infinispan.atomic
 
PutOperation() - Constructor for class org.infinispan.atomic.PutOperation
 
putReferencedObject(int, Object) - Method in class org.infinispan.marshall.UnmarshalledReferences
Adds a referenced object to the list of references

R

raw - Variable in class org.infinispan.marshall.MarshalledValue
 
read() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readBooleanAttribute(Element, String, String, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Retrieves the boolean value of a given attribute for the first encountered instance of elementName
readBooleanContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readBooleanContents(Element, String, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
ReadCommittedEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
ReadCommittedEntry() - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry(Object, Object, long) - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry.Flags - Enum in org.infinispan.container.entries
 
readDouble() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readExternal(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
readExternal(ObjectInput) - Method in class org.infinispan.atomic.NullDelta
 
readExternal(ObjectInput) - Method in class org.infinispan.atomic.Operation
 
readExternal(ObjectInput) - Method in class org.infinispan.atomic.PutOperation
 
readExternal(ObjectInput) - Method in class org.infinispan.atomic.RemoveOperation
 
readExternal(ObjectInput) - Method in class org.infinispan.loaders.bucket.Bucket
 
readExternal(ObjectInput) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
readExternal(ObjectInput) - Method in class org.infinispan.tree.Fqn
 
readExternal(ObjectInput) - Method in class org.infinispan.util.ImmutableListCopy
See ImmutableListCopy.writeExternal(java.io.ObjectOutput) for serialization format
readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
readObject(Unmarshaller) - Method in interface org.infinispan.marshall.jboss.Externalizer
Read an instance from the stream.
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ArrayListExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.BucketExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.DeltaAwareExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ExceptionResponseExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ExtendedResponseExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.GlobalTransactionExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ImmortalCacheEntryExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ImmortalCacheValueExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ImmutableMapExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.JGroupsAddressExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.LinkedListExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.MapExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.MarshalledValueExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.MortalCacheEntryExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.MortalCacheValueExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.ReplicableCommandExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.SetExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.SingletonListExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.SuccessfulResponseExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.TransactionLogExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.TransientCacheEntryExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.TransientCacheValueExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.TransientMortalCacheEntryExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.externalizers.TransientMortalCacheValueExternalizer
 
ReadOnlyStore - Class in org.infinispan.loaders.decorators
A decorator that makes the underlying store a CacheLoader, i.e., suppressing all write methods.
ReadOnlyStore(CacheStore) - Constructor for class org.infinispan.loaders.decorators.ReadOnlyStore
 
readPropertiesContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of a named sub element within a given element, and attempts to parse the contents as a Java properties file.
readPropertiesContents(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
readReference(ObjectInput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated. This version of readReference is written to solve JBCACHE-1211, where references are encoded as ints rather than shorts.
readRoot(InputStream) - Method in class org.infinispan.config.parsing.RootElementBuilder
 
readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readStringContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of the first occurence of elementName under the given element, trimming results of whitespace.
readUnsignedByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUnsignedInt(ObjectInput) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedInt(ObjectInput) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
Reads an int stored in variable-length format.
readUnsignedLong(ObjectInput) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(ObjectInput) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
Reads a long stored in variable-length format.
readUnsignedShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUTF() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
receive(Message) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
ReclosableLatch - Class in org.infinispan.util.concurrent
A thread gat, that uses an AbstractQueuedSynchronizer.
ReclosableLatch() - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
ReclosableLatch(boolean) - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
recover(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
ReentrantPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A per-entry lock container for ReentrantLocks
ReentrantPerEntryLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
ReentrantStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A LockContainer that holds ReentrantLocks
ReentrantStripedLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
Creates a new LockContainer which uses a certain number of shared locks across all elements that need to be locked.
ReflectionUtil - Class in org.infinispan.util
Basic reflection utilities to enhance what the JDK provides.
ReflectionUtil() - Constructor for class org.infinispan.util.ReflectionUtil
 
registerComponent(Object, Class) - Method in class org.infinispan.factories.AbstractComponentRegistry
Registers a component in the registry under the given type, and injects any dependencies needed.
registerComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerComponent(Object, String) - Method in class org.infinispan.factories.ComponentRegistry
 
registerConfiguration(String, Configuration) - Method in interface org.infinispan.config.ConfigurationRegistry
Register the given configuration under the given name.
registerDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.AbstractComponentRegistry
Registers the default class loader.
registerMBeans() - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Performs the MBean registration.
registerNamedComponentRegistry(ComponentRegistry, String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
Register a Synchronization callback with this transaction.
registerToMBeanServer() - Method in class org.infinispan.jmx.CacheJmxRegistration
Here is where the registration is being performed.
rehash(Collection<Address>) - Method in interface org.infinispan.distribution.DistributionManager
 
rehash(Collection<Address>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
releaseAllLocks(List<Object>) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases locks on all keys passed in.
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Destroys a connection.
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
releaseGlobalLock(boolean) - Method in class org.infinispan.loaders.LockSupportCacheStore
Based on the supplied param, releases a global read(false) or write (true) lock.
releaseGlobalLock(boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
releaseLock(Object) - Method in interface org.infinispan.factories.EntryFactory
 
releaseLock(Object) - Method in class org.infinispan.factories.EntryFactoryImpl
 
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
releaseLock(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases a lock the caller may be holding.
releaseProcessingLock() - Method in interface org.infinispan.remoting.transport.DistributedSync
Releases any processing locks that may be held by the current thread.
releaseProcessingLock() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
releaseRPCBlock() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
releaseSync() - Method in interface org.infinispan.remoting.transport.DistributedSync
Releases the sync.
releaseSync() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
REMOTE - Static variable in class org.infinispan.jopr.infinispan.InfinispanDiscovery
 
RemoteCommandFactory - Class in org.infinispan.commands
Specifically used to create un-initialized ReplicableCommands from a byte stream.
RemoteCommandFactory() - Constructor for class org.infinispan.commands.RemoteCommandFactory
 
RemoteTransaction - Class in org.infinispan.transaction.xa
Defines the state of a remotelly originated transaction.
RemoteTransaction(WriteCommand[], GlobalTransaction) - Constructor for class org.infinispan.transaction.xa.RemoteTransaction
 
RemoteTxInvocationContext - Class in org.infinispan.context.impl
Context to be used for transaction that originated remotelly.
RemoteTxInvocationContext() - Constructor for class org.infinispan.context.impl.RemoteTxInvocationContext
 
remove(Object, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
remove(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object, Flag...) - Method in interface org.infinispan.AdvancedCache
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
remove(Object, Object) - Method in class org.infinispan.CacheDelegate
 
remove(Object) - Method in class org.infinispan.CacheDelegate
 
remove(Object, Flag...) - Method in class org.infinispan.CacheDelegate
 
remove(Object, Object, Flag...) - Method in class org.infinispan.CacheDelegate
 
remove(Object) - Method in interface org.infinispan.container.DataContainer
Removes an entry from the cache
remove() - Method in class org.infinispan.container.FIFODataContainer.LinkedIterator
 
remove(Object) - Method in class org.infinispan.container.FIFODataContainer
 
remove(Object) - Method in class org.infinispan.container.SimpleDataContainer
 
remove() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer.LinkedIterator
 
remove(Object) - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
remove(Object) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Removes an entry in the store. This implementation delegates to StoredMap.remove(Object)
remove(Object) - Method in interface org.infinispan.loaders.CacheStore
Removes an entry in the store.
remove(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
remove(Object) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Remove - Class in org.infinispan.loaders.modifications
Represents a CacheStore.remove(Object) modification
Remove(Object) - Constructor for class org.infinispan.loaders.modifications.Remove
 
remove(String) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
Removes the Infinispan bucket from the S3 Bucket at location key
remove(String) - Method in interface org.infinispan.loaders.s3.S3Bucket
Removes the Infinispan bucket from the S3 Bucket at location key
remove(K) - Method in interface org.infinispan.tree.Node
Removes the mapping for this key from this node if it is present.
remove(K, Flag...) - Method in interface org.infinispan.tree.Node
 
remove(K) - Method in class org.infinispan.tree.NodeImpl
 
remove(K, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
remove(Fqn, K) - Method in interface org.infinispan.tree.TreeCache
Removes the mapping for this key from a Node.
remove(Fqn, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
remove(String, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
remove(String, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
remove(Fqn, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(Fqn, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(String, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(String, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(Object) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Removes the mapping for the specified key from this map if present.
remove(Object) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
remove(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
remove(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
remove(Object) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Removes the specified element from this set if it is present.
remove0(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
removeAll(Set<Object>) - Method in class org.infinispan.loaders.AbstractCacheStore
 
removeAll(Set<Object>) - Method in interface org.infinispan.loaders.CacheStore
Bulk remove operation
removeAll(Set<Object>) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
removeAll(Set<Object>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
removeAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ImmutableListCopy
 
removeAllCacheListeners() - Method in class org.infinispan.notifications.AbstractListenerImpl
Removes all listeners from the notifier
removeAsync(Object, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeAsync(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeAsync(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeAsync(Object, Flag...) - Method in interface org.infinispan.AdvancedCache
 
removeAsync(Object) - Method in interface org.infinispan.Cache
Asynchronous version of Map.remove(Object).
removeAsync(Object, Object) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.remove(Object, Object).
removeAsync(Object, Flag...) - Method in class org.infinispan.CacheDelegate
 
removeAsync(Object) - Method in class org.infinispan.CacheDelegate
 
removeAsync(Object, Object) - Method in class org.infinispan.CacheDelegate
 
removeChild(Fqn) - Method in interface org.infinispan.tree.Node
Removes a child node specified by the given relative Fqn.
removeChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
removeChild(Object) - Method in interface org.infinispan.tree.Node
Removes a child node specified by the given name.
removeChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
removeChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
removeChildren() - Method in interface org.infinispan.tree.Node
 
removeChildren(Flag...) - Method in interface org.infinispan.tree.Node
 
removeChildren() - Method in class org.infinispan.tree.NodeImpl
 
removeChildren(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
RemoveCommand - Class in org.infinispan.commands.write
 
RemoveCommand(Object, Object, CacheNotifier) - Constructor for class org.infinispan.commands.write.RemoveCommand
 
RemoveCommand() - Constructor for class org.infinispan.commands.write.RemoveCommand
 
removed(Event) - Method in class org.infinispan.demo.InfinispanDemo.CacheListener
 
removedEntries - Variable in class org.infinispan.util.Util.MapModifications
 
removeEntry(Object) - Method in class org.infinispan.loaders.bucket.Bucket
 
removeExpiredEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
removeInterceptor(int) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(int) - Method in interface org.infinispan.AdvancedCache
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 CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor of specified type.
removeInterceptor(int) - Method in class org.infinispan.CacheDelegate
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.CacheDelegate
 
removeInterceptor(int) - Method in class org.infinispan.interceptors.InterceptorChain
Removes the interceptor at the given postion.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Removes all the occurences of supplied interceptor type from the chain.
removeListener(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeListener(Object) - Method in class org.infinispan.CacheDelegate
 
removeListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
removeListener(Object) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
removeListener(Object) - Method in interface org.infinispan.notifications.Listenable
Removes a listener from the component.
removeLocalTransaction(Transaction) - Method in class org.infinispan.transaction.xa.TransactionTable
Removes the TransactionXaAdapter coresponding to the given tx.
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Lookups a bucket where the given key is stored.
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.context.EntryLookup
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
removeNode(Fqn) - Method in interface org.infinispan.tree.TreeCache
Removes a Node indicated by absolute Fqn.
removeNode(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
removeNode(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
removeNode(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
removeNode(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
RemoveOperation<K,V> - Class in org.infinispan.atomic
 
RemoveOperation() - Constructor for class org.infinispan.atomic.RemoveOperation
 
removeRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.TransactionTable
Removes the RemoteTransaction coresponding to the given tx.
removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
RepeatableReadEntry - Class in org.infinispan.container.entries
An extension of ReadCommittedEntry that provides Repeatable Read semantics
RepeatableReadEntry(Object, Object, long) - Constructor for class org.infinispan.container.entries.RepeatableReadEntry
 
replace(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replace(K, V, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replace(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replace(K, V, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replace(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replace(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object), which takes in lifespan parameters.
replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object), which takes in lifespan parameters.
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, V) - Method in class org.infinispan.CacheDelegate
 
replace(K, V) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replace(K, V) - Method in interface org.infinispan.tree.Node
Replace entry for key only if currently mapped to some value.
replace(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
replace(K, V, V) - Method in interface org.infinispan.tree.Node
Replace entry for key only if currently mapped to given value.
replace(K, V, V, Flag...) - Method in interface org.infinispan.tree.Node
 
replace(K, V) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replaceAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.Node
Similar to Node.putAll(java.util.Map) except that it removes any entries that exists in the data map first.
replaceAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.Node
 
replaceAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.NodeImpl
 
replaceAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replaceAncestor(Fqn, Fqn) - Method in class org.infinispan.tree.Fqn
Creates a new Fqn whose ancestor has been replaced with the new ancestor passed in.
replaceAsync(K, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replaceAsync(K, V, V, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replaceAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replaceAsync(K, V, V, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in interface org.infinispan.AdvancedCache
 
replaceAsync(K, V) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.replace(Object, Object).
replaceAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, long, TimeUnit).
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, V) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.replace(Object, Object, Object).
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, Object, long, TimeUnit).
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, V, Flag...) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit, Flag...) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, V) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
ReplaceCommand - Class in org.infinispan.commands.write
 
ReplaceCommand() - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
ReplaceCommand(Object, Object, Object, long, long) - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
ReplicableCommand - Interface in org.infinispan.commands
The core of the command-based cache framework.
ReplicableCommandExternalizer - Class in org.infinispan.marshall.jboss.externalizers
ReplicableCommandExternalizer.
ReplicableCommandExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.ReplicableCommandExternalizer
 
ReplicationException - Exception in org.infinispan.remoting
Thrown when a replication problem occurred
ReplicationException() - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationException(Throwable) - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationException(String) - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationException(String, Throwable) - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationInterceptor - Class in org.infinispan.interceptors
Takes care of replicating modifications to other caches in a cluster.
ReplicationInterceptor() - Constructor for class org.infinispan.interceptors.ReplicationInterceptor
 
ReplicationQueue - Class in org.infinispan.remoting
Periodically (or when certain size is exceeded) takes elements and replicates them.
ReplicationQueue() - Constructor for class org.infinispan.remoting.ReplicationQueue
 
ReplicationQueueFactory - Class in org.infinispan.factories
Factory for ReplicationQueue.
ReplicationQueueFactory() - Constructor for class org.infinispan.factories.ReplicationQueueFactory
 
RequestIgnoredResponse - Class in org.infinispan.remoting.responses
Indicates that the request was ignored,
reset() - Method in class org.infinispan.config.RuntimeConfig
Resets the runtime to default values.
reset() - Method in interface org.infinispan.context.FlagContainer
 
reset() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
reset() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
reset() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
reset() - Method in class org.infinispan.remoting.ReplicationQueue
 
resetNonVolatile() - Method in class org.infinispan.factories.AbstractComponentRegistry
Removes any components not annotated as @NonVolatile.
resetStatistics() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
Resets statistics gathered.
resetStatistics() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.TxInterceptor
 
resetStatistics() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Resets an interceptor's cache statistics
resetStatistics() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
ResourceDMBean - Class in org.infinispan.jmx
This class was entirely copied from jgroups 2.7 (same name there).
ResourceDMBean(Object) - Constructor for class org.infinispan.jmx.ResourceDMBean
 
Response - Interface in org.infinispan.remoting.responses
A response to be sent back to a remote caller
ResponseFilter - Interface in org.infinispan.remoting.rpc
A mechanism of filtering RPC responses.
ResponseGenerator - Interface in org.infinispan.remoting.responses
A component that generates responses as is expected by different cache setups
ResponseGeneratorFactory - Class in org.infinispan.factories
Creates a ResponseGenerator
ResponseGeneratorFactory() - Constructor for class org.infinispan.factories.ResponseGeneratorFactory
 
ResponseMode - Enum in org.infinispan.remoting.rpc
// TODO: Manik: Document this!
restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
 
resume(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
Associates the supplied InvocationContext with the calling thread.
resume(InvocationContext) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
resume(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Resume the association of the calling thread with the given transaction.
retainAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ImmutableListCopy
 
retrieveFromRemoteSource(Object) - Method in interface org.infinispan.distribution.DistributionManager
Retrieves a cache entry from a remote source
retrieveFromRemoteSource(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
retrieveState(String, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
Initiates a state retrieval process from neighbouring caches.
retrieveState(String, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
retrieveState(String, Address, long) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
retrieveState(String, Address, long) - Method in interface org.infinispan.remoting.transport.Transport
Initiates a state retrieval from a specific cache (by typically invoking InboundInvocationHandler.generateState(String, java.io.OutputStream)), and applies this state to the current cache via the InboundInvocationHandler.applyState(String, java.io.InputStream) callback.
reverseIterator() - Method in interface org.infinispan.util.ReversibleOrderedSet
 
reverseIterator() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
 
ReversibleOrderedSet<E> - Interface in org.infinispan.util
A set that allows reverse iteration of the set elements, exposed via the ReversibleOrderedSet.reverseIterator() method.
rewire() - Method in class org.infinispan.factories.AbstractComponentRegistry
Rewires components.
rewireNamedRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
rollback() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
rollback() - Method in interface org.infinispan.container.entries.CacheEntry
Rolls back changes
rollback() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.AbstractCacheStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Rolls back a transaction that has been previously prepared

This method may be invoked on a transaction for which there is no prior CacheStore.prepare(java.util.List, org.infinispan.transaction.xa.GlobalTransaction, boolean).

This implementation calls completeTransaction with an argument of false.

rollback(GlobalTransaction) - Method in interface org.infinispan.loaders.CacheStore
Rolls back a transaction that has been previously prepared

This method may be invoked on a transaction for which there is no prior CacheStore.prepare(java.util.List, org.infinispan.transaction.xa.GlobalTransaction, boolean).

rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
rollback() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Rolls back the transaction associated with the calling thread.
rollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
Rolls back this transaction.
rollback() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Rolls back this transaction.
rollback(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionLog
 
rollback(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
RollbackCommand - Class in org.infinispan.commands.tx
// TODO: MANIK: Document this
RollbackCommand(GlobalTransaction) - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
RollbackCommand() - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
ROOT - Static variable in class org.infinispan.tree.Fqn
Immutable root Fqn.
root() - Static method in class org.infinispan.tree.Fqn
 
RootElementBuilder - Class in org.infinispan.config.parsing
Parses an xml files and validates xml elements form RootElementBuilder.HORIZON_NS namespace according to the configured schema.
RootElementBuilder(ErrorHandler) - Constructor for class org.infinispan.config.parsing.RootElementBuilder
 
RootElementBuilder(ErrorHandler, boolean) - Constructor for class org.infinispan.config.parsing.RootElementBuilder
 
RootElementBuilder() - Constructor for class org.infinispan.config.parsing.RootElementBuilder
 
RootElementBuilder(boolean) - Constructor for class org.infinispan.config.parsing.RootElementBuilder
 
rpcManager - Variable in class org.infinispan.CacheDelegate
 
rpcManager - Variable in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
RpcManager - Interface in org.infinispan.remoting.rpc
Provides a mechanism for communicating with other caches in the cluster, by formatting and passing requests down to the registered Transport.
RpcManagerFactory - Class in org.infinispan.factories
An extension of the EmptyConstructorFactory that places a component in the RuntimeConfig after creating it.
RpcManagerFactory() - Constructor for class org.infinispan.factories.RpcManagerFactory
 
RpcManagerImpl - Class in org.infinispan.remoting.rpc
This component really is just a wrapper around a Transport implementation, and is used to set up the transport and provide lifecycle and dependency hooks into external transport implementations.
RpcManagerImpl() - Constructor for class org.infinispan.remoting.rpc.RpcManagerImpl
 
RuntimeConfig - Class in org.infinispan.config
 
RuntimeConfig() - Constructor for class org.infinispan.config.RuntimeConfig
 

S

S3Bucket<B,C extends S3Connection> - Interface in org.infinispan.loaders.s3

This interface defines the interactons between the S3CacheStore and Amazon S3.

S3CacheStore - Class in org.infinispan.loaders.s3
By default, a JClouds implementation of a BucketBasedCacheStore.
S3CacheStore() - Constructor for class org.infinispan.loaders.s3.S3CacheStore
 
S3CacheStoreConfig - Class in org.infinispan.loaders.s3
Configures S3CacheStore.
S3CacheStoreConfig() - Constructor for class org.infinispan.loaders.s3.S3CacheStoreConfig
 
S3Connection<C,B> - Interface in org.infinispan.loaders.s3
Represents a connection to Amazon S3.
S3ConnectionException - Exception in org.infinispan.loaders.s3
An exception thrown by a S3Bucket implementation if there are problems reading from S3.
S3ConnectionException() - Constructor for exception org.infinispan.loaders.s3.S3ConnectionException
 
S3ConnectionException(String) - Constructor for exception org.infinispan.loaders.s3.S3ConnectionException
 
S3ConnectionException(String, Throwable) - Constructor for exception org.infinispan.loaders.s3.S3ConnectionException
 
S3ConnectionException(Throwable) - Constructor for exception org.infinispan.loaders.s3.S3ConnectionException
 
s3Service - Variable in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
safeClose(InputStream) - Method in class org.infinispan.loaders.AbstractCacheStore
 
safeClose(OutputStream) - Method in class org.infinispan.loaders.AbstractCacheStore
 
safeClose(Statement) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(Connection) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(ResultSet) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(InputStream) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
 
safeEquals(Object, Object) - Static method in class org.infinispan.util.Util
Null-safe equality test.
saveBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
This method assumes that the bucket is already persisted in the database.
saveBucket(Bucket) - Method in class org.infinispan.loaders.file.FileCacheStore
 
saveBucket(Bucket) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
saveBucket(Bucket) - Method in class org.infinispan.loaders.s3.S3CacheStore
 
ScheduledExecutorFactory - Interface in org.infinispan.executors
Used to configure and create scheduled executors
Scope - Annotation Type in org.infinispan.factories.scopes
Defines the scope of a component in a cache system.
ScopeDetector - Class in org.infinispan.factories.scopes
Retrieves the declated scope of a component
ScopeDetector() - Constructor for class org.infinispan.factories.scopes.ScopeDetector
 
Scopes - Enum in org.infinispan.factories.scopes
The different scopes that can be declared for a component in the cache system.
sendNotification(Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
sendNotification(Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
SEPARATOR - Static variable in class org.infinispan.tree.Fqn
Separator between FQN elements.
serialize(Object) - Method in class org.infinispan.loaders.jdbm.JdbmSerializer
 
serialize() - Method in class org.infinispan.marshall.MarshalledValue
 
setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setAfterInterceptor(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately after the first occurance of an interceptor having the given class.
setAfterInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately after the first occurance of an interceptor having the given class.
setAllowDuplicateDomains(boolean) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncCacheListenerExecutor(ExecutorService) - Method in class org.infinispan.config.RuntimeConfig
This is used to set the executor to use for asynchronous cache listeners.
setAsyncListenerExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncListenerExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncListenerExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncSerializationExecutor(ExecutorService) - Method in class org.infinispan.config.RuntimeConfig
This is used to set the executor to use for asynchronous cache operations.
setAsyncSerializationExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncSerializationExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncSerializationExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setAsyncStoreConfig(AsyncStoreConfig) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAwsAccessKey(String) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setAwsSecretKey(String) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setBeforeInterceptor(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately before the first occurance of an interceptor having the given class.
setBeforeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately before the first occurance of an interceptor having the given class.
setBinaryTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setBucket(String) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setBucketName(String) - Method in class org.infinispan.loaders.bucket.Bucket
 
setBucketTableName(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setCache(Cache) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setCacheDbName(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setCacheLoaderClassName(String) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
setCacheLoaderClassName(String) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setCacheLoaderClassName(String) - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
setCacheLoaderConfigs(List<CacheLoaderConfig>) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.Configuration
 
setCacheManager(CacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheManagerNotifier(CacheManagerNotifier) - Method in class org.infinispan.factories.ComponentRegistry
 
setCacheMode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration
 
setCacheMode(String) - Method in class org.infinispan.config.Configuration
 
setCacheModeString(String) - Method in class org.infinispan.config.Configuration
 
setCacheName(String) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCaches(Collection<Address>) - Method in interface org.infinispan.distribution.ConsistentHash
 
setCaches(Collection<Address>) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
setCacheStore() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
setCatalogDbName(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setChanged() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setComparatorClassName(String) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
Sets comparatorClassName.
setConcurrencyLevel(int) - Method in class org.infinispan.config.Configuration
 
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Name of the connection factory class.
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
setConnectionFactoryConfig(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Url connection to the database.
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Jdbc connection string for connecting to the database.
setConsistentHashClass(String) - Method in class org.infinispan.config.Configuration
 
setContextFlag(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Unility method that sets a given context flag.
setContextFlag(AbstractInvocationContext.ContextFlag, boolean) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility value that sets or unsets a context flag based on a boolean passed in
setCreated(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setCreated(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setCreated(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setCreated(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
If true, and the table is missing it will be created when starting the cache store.
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setCreateTableOnStartForBinary(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setCreateTableOnStartForStrings(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration
 
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the name of the column where the StoredEntry will be binary stored.
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDataColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the type of the column where data will be binary stored.
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDataColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.InternalCacheFactory
Allows users to specify a default class loader to use for both the construction and running of the cache.
setDefaultConfiguration(Configuration) - Method in class org.infinispan.config.GlobalConfiguration
 
setDelegate(CacheStore) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
setDependencies(DataContainer) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
setDependencies(LockManager, DataContainer, EntryFactory) - Method in class org.infinispan.interceptors.LockingInterceptor
 
setDependencies(CacheNotifier, CacheLoaderManager, DataContainer) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
setDistributedSyncTimeout(long) - Method in class org.infinispan.config.GlobalConfiguration
 
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Driver class, will be loaded before initializing the ConnectionFactory
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
The name of the driver used for connecting to the database.
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
If true, the table will be created when cache store is stopped.
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDropTableOnExitForBinary(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDropTableOnExitForStrings(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setEnabled(boolean) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setEvictionMaxEntries(int) - Method in class org.infinispan.config.Configuration
 
setEvictionScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setEvictionScheduledExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setEvictionScheduledExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration
 
setEvictionWakeUpInterval(long) - Method in class org.infinispan.config.Configuration
 
setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
setExpirationLifespan(long) - Method in class org.infinispan.config.Configuration
 
setExpirationMaxIdle(long) - Method in class org.infinispan.config.Configuration
 
setExpiryDbName(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setExposeGlobalJmxStatistics(boolean) - Method in class org.infinispan.config.GlobalConfiguration
 
setExposeJmxStatistics(boolean) - Method in class org.infinispan.config.Configuration
 
SetExternalizer - Class in org.infinispan.marshall.jboss.externalizers
Set externalizer for all set implementations, i.e.
SetExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.SetExternalizer
 
setFetchInMemoryState(boolean) - Method in class org.infinispan.config.Configuration
 
setFetchPersistentState(boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setFetchPersistentState(boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setFirst(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this interceptor be the first one in the chain?
setFirstInChain(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Mainly used by unit tests to replace the interceptor chain with the starting point passed in.
setFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Unility method that sets the value of the given flag to true.
setFlags(Flag...) - Method in interface org.infinispan.context.FlagContainer
 
setFlags(Collection<Flag>) - Method in interface org.infinispan.context.FlagContainer
 
setFlags(Flag...) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setFlags(Collection<Flag>) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the name of the column where the id will be stored.
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setIdColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
sql equivalent for java's String.
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setIdColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIgnoreModifications(boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setIgnoreModifications(boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setIndex(int) - Method in class org.infinispan.config.CustomInterceptorConfig
Put this interceptor at the specified index, after the default chain is built.
setInvocationBatchingEnabled(boolean) - Method in class org.infinispan.config.Configuration
Enables invocation batching if set to true.
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration
 
setIsolationLevel(String) - Method in class org.infinispan.config.Configuration
 
setJGroupsAddress(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
setJmxDomain(String) - Method in class org.infinispan.config.GlobalConfiguration
If JMX statistics are enabled then all 'published' JMX objects will appear under this name.
setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
setKey(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setKey(Object) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setKey2StringMapperClass(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setKey2StringMapperClass(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Name of the class implementing Key2StringMapper.
setL1CacheEnabled(boolean) - Method in class org.infinispan.config.Configuration
 
setL1Lifespan(long) - Method in class org.infinispan.config.Configuration
 
setL1OnRehash(boolean) - Method in class org.infinispan.config.Configuration
 
setLast(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this intercepto be the last one in the chain?
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setLifespan(long) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the lifespan of the entry.
setLifespan(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
setLifespan(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Sets the lifespan of the entry.
setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setLifespan(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setLocalAddress(Address) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setLocation(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setLocation(String) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setLocation(String) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setLockAcquisitionTimeout(long) - Method in class org.infinispan.config.Configuration
 
setLockAcquisitionTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setLockAcquistionTimeout(long) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setLockAcquistionTimeout(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockAcquistionTimeout(long) - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
setLockConcurrencyLevel(int) - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
Sets number of threads expected to use this class concurrently.
setLockConcurrencyLevelForBinary(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockConcurrencyLevelForStrings(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
setMarshallerClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setMarshallVersion(short) - Method in class org.infinispan.config.GlobalConfiguration
 
setMarshallVersion(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setMaxConnections(int) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setMaxIdle(long) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the maximum idle time of the entry.
setMaxIdle(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
setMaxIdle(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Sets the maximum idle time of the entry.
setMaxIdle(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setMaxTxRetries(int) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setMBeanServer(MBeanServer) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
setMBeanServerLookup(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setMembers(List<Address>) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
setModifications(WriteCommand[]) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
setNetworkFuture(Future<Object>) - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
setNewMemberList(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setNext(CommandInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Sets the next interceptor in the chain to the interceptor passed in.
setNumOwners(int) - Method in class org.infinispan.config.Configuration
 
setOriginLocal(boolean) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
setOriginLocal(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.LockControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.SizeCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
setParameters(int, Object[]) - Method in interface org.infinispan.commands.ReplicableCommand
Used by the CommandsFactory to create a command from raw data read off a stream.
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.PrepareCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ClearCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.InvalidateCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.PutMapCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setPassivation(boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setPassword(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Database username's password.
setPassword(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setPassword(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setPassword(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Database username's password.
setPollWait(long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setPre(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setPreload(boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setProperties(Properties) - Method in class org.infinispan.config.PluggableConfigurationComponent
 
setProperties(String) - Method in class org.infinispan.config.PluggableConfigurationComponent
 
setProxyHost(String) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setProxyPort(int) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setPurgeOnStartup(boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setPurgeOnStartup(boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setPurgeSynchronously(boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setPurgeSynchronously(boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setPushStateTimeout(long) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
setPushStateWhenCoordinator(boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
setPutIfAbsent(boolean) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setQueueSize(int) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setRehashWaitTime(long) - Method in class org.infinispan.config.Configuration
 
setRemoteCallTimeout(long) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
setRemoteTransaction(RemoteTransaction) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setRemoved(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setReplicationQueueScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setReplicationQueueScheduledExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setReplicationQueueScheduledExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setReplQueueInterval(long) - Method in class org.infinispan.config.Configuration
 
setReplQueueInterval(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setReplQueueMaxElements(int) - Method in class org.infinispan.config.Configuration
 
setRequestTimeout(long) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setResponseValue(Object) - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Mark the transaction associated with the calling thread for rollback only.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRPCManager(RpcManager) - Method in class org.infinispan.config.RuntimeConfig
 
setSecure(boolean) - Method in class org.infinispan.loaders.s3.S3CacheStoreConfig
 
setShared(boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setShutdownHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration
 
setShutdownHookBehavior(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setSingletonStoreConfig(SingletonStoreConfig) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setSingletonStoreEnabled(boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
setState(byte[]) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setState(String, byte[]) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setState(InputStream) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setState(String, InputStream) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setStateException - Variable in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
Reference to an exception that was raised during state installation on this cache.
setStateRetrievalTimeout(long) - Method in class org.infinispan.config.Configuration
 
setStateRetrievalTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.TxInterceptor
 
setStatisticsEnabled(boolean) - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Enables an interceptor's cache statistics If true, the interceptor will capture statistics and make them available through the mbean.
setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
setStatus(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
setStreamBufferSize(int) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setStringsTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setStringsTableName(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the name of the table where data will be stored.
setSyncCommitPhase(boolean) - Method in class org.infinispan.config.Configuration
 
setSyncReplTimeout(long) - Method in class org.infinispan.config.Configuration
 
setSyncReplTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setSyncRollbackPhase(boolean) - Method in class org.infinispan.config.Configuration
 
setTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
setTableName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTableNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTableNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setterMethod(Class, Class) - Static method in class org.infinispan.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.infinispan.util.BeanUtils
Retrieves a setter name based on a field name passed in
setterName(Class) - Static method in class org.infinispan.util.BeanUtils
Returns a setter for a given class
setThreadPoolSize(int) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the name of the column where the timestamp (Long in java) will be stored.
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTimestampColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnType(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
setTimestampColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTimestampColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTransaction(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Just used for unit tests
setTransactionId(GlobalTransaction) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionManager(TransactionManager) - Method in class org.infinispan.config.RuntimeConfig
 
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration
 
setTransactionSuccessful(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Change the transaction timeout for transactions started by the calling thread with the DummyBaseTransactionManager.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
Change the transaction timeout for transactions started by the calling thread with the DummyBaseTransactionManager.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Change the transaction timeout for transactions started by the calling thread with the DummyUserTransaction.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
setTransport(Transport) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
setTransportClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setTransportProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setTransportProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setUnsafeUnreliableReturnValues(boolean) - Method in class org.infinispan.config.Configuration
 
setupDependencies(DataContainer, CacheNotifier, Cache, InterceptorChain, CacheLoaderManager, DistributionManager, InvocationContextContainer, TransactionTable) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
setUseAsyncMarshalling(boolean) - Method in class org.infinispan.config.Configuration
 
setUseEagerLocking(boolean) - Method in class org.infinispan.config.Configuration
 
setUseFutureReturnType(boolean) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setUseFutureReturnType(boolean) - Method in interface org.infinispan.context.InvocationContext
 
setUseLazyDeserialization(boolean) - Method in class org.infinispan.config.Configuration
 
setUseLockStriping(boolean) - Method in class org.infinispan.config.Configuration
 
setUseReplQueue(boolean) - Method in class org.infinispan.config.Configuration
 
setUserName(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Databse user name.
setUserName(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setUserName(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setUserName(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Database username.
setValid(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setValid(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setValid(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setValue(Object) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setValue(Object) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the value of the entry, returing the previous value
setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
setValue(Object) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setValue(V) - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
setValue(Object, String, Object) - Static method in class org.infinispan.util.ReflectionUtil
 
setValue(V) - Method in class org.infinispan.util.SimpleImmutableEntry
 
setValues(Object, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
setWriteSkewCheck(boolean) - Method in class org.infinispan.config.Configuration
 
setXaCache(TransactionXaAdapter) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
shutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
shutdownNow() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
signalJoinCompleted() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
signalJoinInProgress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
SimpleConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Connection factory implementation that will create database connection on a per invocation basis.
SimpleConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
SimpleDataContainer - Class in org.infinispan.container
Simple data container that does not order entries for eviction, implemented using two ConcurrentHashMaps, one for mortal and one for immortal entries.
SimpleDataContainer() - Constructor for class org.infinispan.container.SimpleDataContainer
 
SimpleImmutableEntry<K,V> - Class in org.infinispan.util
Where is Java 1.6?
SimpleImmutableEntry(Map.Entry<K, V>) - Constructor for class org.infinispan.util.SimpleImmutableEntry
 
SimpleImmutableEntry(K, V) - Constructor for class org.infinispan.util.SimpleImmutableEntry
 
SingleRpcCommand - Class in org.infinispan.commands.remote
Similar to MultipleRpcCommand, but it only aggregates a single command for replication.
SingleRpcCommand(String, ReplicableCommand) - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SingleRpcCommand() - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SingletonListExternalizer - Class in org.infinispan.marshall.jboss.externalizers
SingletonListExternalizer.
SingletonListExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.SingletonListExternalizer
 
SingletonStore - Class in org.infinispan.loaders.decorators
SingletonStore is a delegating cache store used for situations when only one instance should interact with the underlying store.
SingletonStore(CacheStore, Cache, SingletonStoreConfig) - Constructor for class org.infinispan.loaders.decorators.SingletonStore
 
SingletonStore.PushStateException - Exception in org.infinispan.loaders.decorators
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
SingletonStore.PushStateException(String, Throwable) - Constructor for exception org.infinispan.loaders.decorators.SingletonStore.PushStateException
 
SingletonStore.PushStateException(Throwable) - Constructor for exception org.infinispan.loaders.decorators.SingletonStore.PushStateException
 
SingletonStore.SingletonStoreListener - Class in org.infinispan.loaders.decorators
Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
SingletonStore.SingletonStoreListener() - Constructor for class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
 
SingletonStoreConfig - Class in org.infinispan.loaders.decorators
Configuration for a singleton store
SingletonStoreConfig() - Constructor for class org.infinispan.loaders.decorators.SingletonStoreConfig
 
size() - Method in class org.infinispan.AbstractDelegatingCache
 
size() - Method in class org.infinispan.atomic.AtomicHashMap
 
size() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
size() - Method in class org.infinispan.CacheDelegate
 
size() - Method in interface org.infinispan.container.DataContainer
 
size() - Method in class org.infinispan.container.FIFODataContainer.KeySet
 
size() - Method in class org.infinispan.container.FIFODataContainer
 
size() - Method in class org.infinispan.container.SimpleDataContainer
 
size() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer.KeySet
 
size() - Method in class org.infinispan.container.SpinLockBasedFIFODataContainer
 
size() - Method in class org.infinispan.interceptors.InterceptorChain
Returns the number of interceptors in the chain.
size() - Method in class org.infinispan.transaction.TransactionLog
 
size - Variable in class org.infinispan.tree.Fqn
 
size() - Method in class org.infinispan.tree.Fqn
 
size() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
size() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.FastCopyHashMap
 
size() - Method in class org.infinispan.util.ImmutableListCopy
 
size() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns the number of elements in this set (its cardinality).
SizeCommand - Class in org.infinispan.commands.read
Command to calculate the size of the cache
SizeCommand(DataContainer) - Constructor for class org.infinispan.commands.read.SizeCommand
 
skip(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
if this is a shared cache loader and the call is of remote origin, pass up the chain
skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
SpinLockBasedFIFODataContainer - Class in org.infinispan.container
A data container that exposes an iterator that is ordered based on order of entry into the container, with the oldest entries first.
SpinLockBasedFIFODataContainer() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer
 
SpinLockBasedFIFODataContainer.Aux - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.Aux() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.Aux
 
SpinLockBasedFIFODataContainer.KeyIterator - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.KeyIterator() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.KeyIterator
 
SpinLockBasedFIFODataContainer.KeySet - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.KeySet() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.KeySet
 
SpinLockBasedFIFODataContainer.LinkedEntry - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.LinkedEntry() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.LinkedEntry
 
SpinLockBasedFIFODataContainer.LinkedIterator - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.LinkedIterator() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.LinkedIterator
 
SpinLockBasedFIFODataContainer.SpinLock - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.SpinLock() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.SpinLock
 
SpinLockBasedFIFODataContainer.ValueIterator - Class in org.infinispan.container
 
SpinLockBasedFIFODataContainer.ValueIterator() - Constructor for class org.infinispan.container.SpinLockBasedFIFODataContainer.ValueIterator
 
SpinLockBasedLRUDataContainer - Class in org.infinispan.container
A data container that exposes an iterator that is ordered based on least recently used (visited) entries first.
SpinLockBasedLRUDataContainer() - Constructor for class org.infinispan.container.SpinLockBasedLRUDataContainer
 
start() - Method in class org.infinispan.AbstractDelegatingCache
 
start() - Method in class org.infinispan.CacheDelegate
 
start() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
start() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
start() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
start() - Method in class org.infinispan.factories.AbstractComponentRegistry
This starts the components in the cache, connecting to channels, starting service threads, etc.
Start - Annotation Type in org.infinispan.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.infinispan.factories.ComponentRegistry
 
start() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
start() - Method in class org.infinispan.interceptors.DistributionInterceptor
 
start() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
start() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
On start, the mbeans are registered.
start(ResourceContext<InfinispanComponent>) - Method in class org.infinispan.jopr.infinispan.CacheComponent
Start the resource connection
start(ResourceContext) - Method in class org.infinispan.jopr.infinispan.InfinispanComponent
Start the resource connection
start() - Method in interface org.infinispan.lifecycle.Lifecycle
 
start() - Method in class org.infinispan.loaders.AbstractCacheStore
 
start() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Validates configuration, configures and opens the Environment, then opens the databases.
start() - Method in interface org.infinispan.loaders.CacheLoader
 
start() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
start() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
start() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
start() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
start() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
start() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
start() - Method in class org.infinispan.loaders.file.FileCacheStore
 
start() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Starts the connection factory.
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
start() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
start() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
start(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
start() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
start() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
start() - Method in class org.infinispan.loaders.s3.S3CacheStore
 
start() - Method in class org.infinispan.manager.DefaultCacheManager
 
start() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
start() - Method in class org.infinispan.remoting.ReplicationQueue
Starts the asynchronous flush queue.
start() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
start() - Method in interface org.infinispan.remoting.transport.Transport
 
start() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
start(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
start() - Method in class org.infinispan.tree.TreeCacheImpl
 
startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
startBatch() - Method in class org.infinispan.AbstractDelegatingCache
 
startBatch() - Method in class org.infinispan.batch.BatchContainer
Starts a batch
startBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
startBatch() - Method in interface org.infinispan.Cache
Starts a batch.
startBatch() - Method in class org.infinispan.CacheDelegate
 
startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startInterceptor() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
startLockManager() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
startObjectInput(InputStream) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
startObjectInput(InputStream) - Method in interface org.infinispan.marshall.Marshaller
Create and open a new ObjectInput for the given input stream.
startObjectInput(InputStream) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
startObjectInput(InputStream) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
startObjectOutput(OutputStream) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
startObjectOutput(OutputStream) - Method in interface org.infinispan.marshall.Marshaller
Create and open a new ObjectOutput for the given output stream.
startObjectOutput(OutputStream) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
startObjectOutput(OutputStream) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
StateTransferControlCommand - Class in org.infinispan.commands.control
A command that informs caches participating in a state transfer of the various stages in the state transfer process.
StateTransferControlCommand() - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommand(boolean) - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommandExternalizer - Class in org.infinispan.marshall.jboss.externalizers
Deprecated. With new ObjecTable based solution, we're now fully in control of the stream, so no need to put class on the wire. As a result, we can use the exact same trick used by the old marshaller implementation which uses a RemoteCommandFactory to load the class.
StateTransferControlCommandExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.StateTransferControlCommandExternalizer
Deprecated.  
StateTransferException - Exception in org.infinispan.statetransfer
An exception to denote problems in transferring state between cache instances in a cluster
StateTransferException() - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(String) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(String, Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferManager - Interface in org.infinispan.statetransfer
Handles generation and application of state on the cache
StateTransferManagerFactory - Class in org.infinispan.factories
Constructs StateTransferManager instances.
StateTransferManagerFactory() - Constructor for class org.infinispan.factories.StateTransferManagerFactory
 
StateTransferManagerImpl - Class in org.infinispan.statetransfer
 
StateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.StateTransferManagerImpl
 
StateTransferMonitor - Class in org.infinispan.remoting.transport.jgroups
 
StateTransferMonitor() - Constructor for class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
stop() - Method in class org.infinispan.AbstractDelegatingCache
 
stop() - Method in class org.infinispan.CacheDelegate
 
stop() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
stop() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
stop() - Method in class org.infinispan.factories.AbstractComponentRegistry
Stops the cache and sets the cache status to ComponentStatus.TERMINATED once it is done.
Stop - Annotation Type in org.infinispan.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.infinispan.factories.ComponentRegistry
 
stop() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
On stop, the mbeans are unregistered.
stop() - Method in class org.infinispan.jopr.infinispan.CacheComponent
Tear down the rescource connection
stop() - Method in class org.infinispan.jopr.infinispan.InfinispanComponent
Tear down the rescource connection
stop() - Method in interface org.infinispan.lifecycle.Lifecycle
 
stop() - Method in class org.infinispan.loaders.AbstractCacheStore
 
stop() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Stops transaction and purge processing and closes the SleepyCat environment.
stop() - Method in interface org.infinispan.loaders.CacheLoader
 
stop() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
stop() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
stop() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
stop() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
stop() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Closes the connection factory, including all alocated connections etc.
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
stop() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Closes all databases, ignoring exceptions, and nulls references to all database related information.
stop() - Method in class org.infinispan.loaders.s3.S3CacheStore
 
stop() - Method in class org.infinispan.manager.DefaultCacheManager
 
stop() - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
stop() - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
stop() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
stop() - Method in class org.infinispan.remoting.ReplicationQueue
Stops the asynchronous flush queue.
stop() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
stop() - Method in interface org.infinispan.remoting.transport.Transport
 
stop() - Method in class org.infinispan.tree.TreeCacheImpl
 
stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Stores an entry This implementation delegates to StoredMap.put(Object, Object)
store(InternalCacheEntry) - Method in interface org.infinispan.loaders.CacheStore
Stores an entry
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Store - Class in org.infinispan.loaders.modifications
Modification representing CacheStore.store(org.infinispan.container.entries.InternalCacheEntry)
Store(InternalCacheEntry) - Constructor for class org.infinispan.loaders.modifications.Store
 
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Tries to find a bucket corresponding to storedEntry's key, and updates it with the storedEntry.
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
stringAttribs - Variable in class org.infinispan.config.parsing.ParsedAttributes
 
stringRepresentation - Variable in class org.infinispan.tree.Fqn
A cached string representation of this Fqn, used by toString to it isn't calculated again every time.
stringToElement(String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
stringToElementInCoreNS(String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
StripedLock - Class in org.infinispan.util.concurrent.locks
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
StripedLock() - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
This constructor just calls StripedLock.StripedLock(int) with a default concurrency value of 20.
StripedLock(int) - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
subList(int, int) - Method in class org.infinispan.util.ImmutableListCopy
 
submit(Callable<T>) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
submit(Runnable, T) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
submit(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
SuccessfulResponse - Class in org.infinispan.remoting.responses
A successful response
SuccessfulResponse() - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
 
SuccessfulResponse(Object) - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
 
SuccessfulResponseExternalizer - Class in org.infinispan.marshall.jboss.externalizers
Externalizes a SuccessfulResponse
SuccessfulResponseExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.SuccessfulResponseExternalizer
 
SUPPORTED_FORMATS - Static variable in class org.infinispan.config.parsing.ConfigFilesConvertor
 
supportsKey(Class) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
suspect(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
SuspectException - Exception in org.infinispan.remoting.transport.jgroups
Thrown when a member is suspected during remote method invocation
SuspectException() - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
suspend() - Method in interface org.infinispan.context.InvocationContextContainer
Dissasociates thread's invocation context and returns the existing value.
suspend() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
suspend() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Suspend the association the calling thread has to a transaction, and return the suspended transaction.
sync - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
SynchronizedRestarter - Class in org.infinispan.util.concurrent
A class that handles restarts of components via multiple threads.
SynchronizedRestarter() - Constructor for class org.infinispan.util.concurrent.SynchronizedRestarter
 
syncProcessor - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
syncs - Variable in class org.infinispan.transaction.tm.DummyTransaction
 

T

tableExists(Connection, String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
tableExists(Connection) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
TableManipulation - Class in org.infinispan.loaders.jdbc
Contains all the logic of manipulating the table, including creating it if needed and access operations like inserting, selecting etc.
TableManipulation(String, String, String, String, String, String, String) - Constructor for class org.infinispan.loaders.jdbc.TableManipulation
 
TableManipulation() - Constructor for class org.infinispan.loaders.jdbc.TableManipulation
 
target - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
testImmutability(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Checks field modifications via setters
testListenerClassValidity(Class<?>) - Method in class org.infinispan.notifications.AbstractListenerImpl
Tests if a class is properly annotated as a CacheListener and returns whether callbacks on this class should be invoked synchronously or asynchronously.
testListenerMethodValidity(Method, Class, String) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
TimeoutException - Exception in org.infinispan.util.concurrent
Thrown when a timeout occurred.
TimeoutException() - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
TimeoutException(String) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
timestampOfFirstEntryToExpire() - Method in class org.infinispan.loaders.bucket.Bucket
 
tm_ - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
toArray() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
toArray(T[]) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
toArray() - Method in class org.infinispan.util.ImmutableListCopy
 
toArray(T[]) - Method in class org.infinispan.util.ImmutableListCopy
 
toAsync() - Method in enum org.infinispan.config.Configuration.CacheMode
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
toInternalCacheEntry(Object) - Method in interface org.infinispan.container.entries.InternalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
toInternalCacheValue() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Creates a representation of this entry as an InternalCacheValue.
toInternalCacheValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Writes the current count of cachestore entries followed by a pair of byte[]s corresponding to the SleepyCat binary representation of key value.
toStream(ObjectOutput) - Method in interface org.infinispan.loaders.CacheStore
Loads the entire state into a stream, using whichever format is most efficient for the cache loader implementation.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Writes to a stream the number of entries (long) then the entries themselves.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.s3.S3CacheStore
 
toString() - Method in class org.infinispan.atomic.AtomicHashMap
 
toString() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
toString() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
toString() - Method in class org.infinispan.CacheDelegate
 
toString() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
toString() - Method in class org.infinispan.commands.LockControlCommand
 
toString() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
toString() - Method in class org.infinispan.commands.read.SizeCommand
 
toString() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
toString() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
toString() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
toString() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
toString() - Method in class org.infinispan.commands.tx.PrepareCommand
 
toString() - Method in class org.infinispan.commands.write.ClearCommand
 
toString() - Method in class org.infinispan.commands.write.InvalidateCommand
 
toString() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
toString() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
toString() - Method in class org.infinispan.commands.write.PutMapCommand
 
toString() - Method in class org.infinispan.commands.write.RemoveCommand
 
toString() - Method in class org.infinispan.commands.write.ReplaceCommand
 
toString() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
toString() - Method in class org.infinispan.config.CustomInterceptorConfig
 
toString(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
toString() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
toString() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
toString() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
toString() - Method in class org.infinispan.interceptors.InterceptorChain
 
toString() - Method in class org.infinispan.io.ByteBuffer
 
toString() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.bucket.Bucket
 
toString() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
toString() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
toString() - Method in class org.infinispan.loaders.modifications.Clear
 
toString() - Method in class org.infinispan.loaders.modifications.Remove
 
toString() - Method in class org.infinispan.loaders.modifications.Store
 
toString() - Method in class org.infinispan.manager.DefaultCacheManager
 
toString() - Method in class org.infinispan.marshall.MarshalledValue
 
toString() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
toString() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
toString() - Method in exception org.infinispan.remoting.ReplicationException
 
toString() - Method in class org.infinispan.remoting.responses.RequestIgnoredResponse
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
toString() - Method in class org.infinispan.transaction.tm.DummyXid
 
toString() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
toString() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
toString() - Method in class org.infinispan.tree.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.infinispan.tree.NodeImpl
 
toString() - Method in class org.infinispan.tree.NodeKey
 
toString() - Method in class org.infinispan.tree.TreeCacheImpl
 
toString() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
toString() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in exception org.infinispan.util.concurrent.TimeoutException
 
toString() - Method in class org.infinispan.util.SimpleImmutableEntry
 
toString() - Method in class org.infinispan.util.Util.MapModifications
 
toSync() - Method in enum org.infinispan.config.Configuration.CacheMode
 
toTypedProperties(Properties) - Method in class org.infinispan.config.AbstractConfigurationBean
Converts a given Properties instance to an instance of TypedProperties
toTypedProperties(String) - Method in class org.infinispan.config.AbstractConfigurationBean
 
toTypedProperties(Properties) - Static method in class org.infinispan.util.TypedProperties
Factory method that converts a JDK Properties instance to an instance of TypedProperties, if needed.
touch() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
touch() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Updates access timestamps on this instance
touch() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
trace - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
trace - Variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
trace - Variable in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
trace(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
trace(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
trace(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
trace(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
trace(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
trace(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
trace(Object) - Method in interface org.infinispan.util.logging.Log
 
trace(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
trace(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
trace(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
TransactionalEvent - Interface in org.infinispan.notifications.cachelistener.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.
TransactionBoundaryCommand - Interface in org.infinispan.commands.tx
// TODO: MANIK: Document this
TransactionCompleted - Annotation Type in org.infinispan.notifications.cachelistener.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.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionCompleted.
TransactionLog - Class in org.infinispan.transaction
Logs transactions and writes for Non-Blocking State Transfer
TransactionLog() - Constructor for class org.infinispan.transaction.TransactionLog
 
TransactionLog.LogEntry - Class in org.infinispan.transaction
 
TransactionLog.LogEntry(GlobalTransaction, WriteCommand...) - Constructor for class org.infinispan.transaction.TransactionLog.LogEntry
 
TransactionLogExternalizer - Class in org.infinispan.marshall.jboss.externalizers
TransactionLogExternalizer.
TransactionLogExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.TransactionLogExternalizer
 
transactionManager - Variable in class org.infinispan.CacheDelegate
 
TransactionManagerFactory - Class in org.infinispan.factories
Uses a number of mechanisms to retrieve a transaction manager.
TransactionManagerFactory() - Constructor for class org.infinispan.factories.TransactionManagerFactory
 
TransactionManagerLookup - Interface in org.infinispan.transaction.lookup
Factory interface, allows Cache to use different transactional systems.
TransactionRegistered - Annotation Type in org.infinispan.notifications.cachelistener.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.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionRegistered.
TransactionTable - Class in org.infinispan.transaction.xa
Repository for RemoteTransaction and TransactionXaAdapters (locally originated trasactions).
TransactionTable() - Constructor for class org.infinispan.transaction.xa.TransactionTable
 
TransactionXaAdapter - Class in org.infinispan.transaction.xa
This acts both as an local CacheTransaction and implementor of an XAResource that will be called by tx manager on various tx stages.
TransactionXaAdapter(GlobalTransaction, InvocationContextContainer, InterceptorChain, CommandsFactory, Configuration, TransactionTable, Transaction) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
transformForL1(CacheEntry) - Method in interface org.infinispan.distribution.DistributionManager
Transforms a cache entry so it is marked for L1 rather than the primary cache data structure.
transformForL1(CacheEntry) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
TransientCacheEntry - Class in org.infinispan.container.entries
A cache entry that is transient, i.e., it can be considered expired afer a period of not being used
TransientCacheEntryExternalizer - Class in org.infinispan.marshall.jboss.externalizers
TransientCacheEntryExternalizer.
TransientCacheEntryExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.TransientCacheEntryExternalizer
 
TransientCacheValue - Class in org.infinispan.container.entries
A transient cache value, to correspond with TransientCacheEntry
TransientCacheValueExternalizer - Class in org.infinispan.marshall.jboss.externalizers
TransientCacheValueExternalizer.
TransientCacheValueExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.TransientCacheValueExternalizer
 
TransientMortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is both transient and mortal.
TransientMortalCacheEntry(Object, Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
 
TransientMortalCacheEntryExternalizer - Class in org.infinispan.marshall.jboss.externalizers
TransientMortalCacheEntryExternalizer.
TransientMortalCacheEntryExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.TransientMortalCacheEntryExternalizer
 
TransientMortalCacheValue - Class in org.infinispan.container.entries
A transient, mortal cache value to correspond with TransientMortalCacheEntry
TransientMortalCacheValueExternalizer - Class in org.infinispan.marshall.jboss.externalizers
TransientMortalCacheValueExternalizer.
TransientMortalCacheValueExternalizer() - Constructor for class org.infinispan.marshall.jboss.externalizers.TransientMortalCacheValueExternalizer
 
Transport - Interface in org.infinispan.remoting.transport
An interface that provides a communication link with remote caches.
TransportFactory - Class in org.infinispan.factories
Factory for Transport implementations
TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
 
TreeCache<K,V> - Interface in org.infinispan.tree
This is a tree-like facade around a Cache allowing for efficient tree-style access to cached data.
TreeCacheFactory - Class in org.infinispan.tree
Factory class that contains API for users to create instances of TreeCache
TreeCacheFactory() - Constructor for class org.infinispan.tree.TreeCacheFactory
 
TreeCacheImpl<K,V> - Class in org.infinispan.tree
 
TreeCacheImpl(Cache<K, V>) - Constructor for class org.infinispan.tree.TreeCacheImpl
 
TreeStructureSupport - Class in org.infinispan.tree
 
TreeStructureSupport(Cache, BatchContainer, InvocationContextContainer) - Constructor for class org.infinispan.tree.TreeStructureSupport
 
tryAcquire(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
tryLock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryLock(long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryRelease(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryReleaseShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
TxInterceptor - Class in org.infinispan.interceptors
Interceptor in charge with handling transaction related operations, e.g enlisting cache as an transaction participant, propagating remotely initiated changes.
TxInterceptor() - Constructor for class org.infinispan.interceptors.TxInterceptor
 
TxInvocationContext - Interface in org.infinispan.context.impl
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
txMods - Variable in class org.infinispan.interceptors.InvalidationInterceptor
 
txParticipants - Variable in class org.infinispan.context.impl.AbstractTxInvocationContext
 
txTable - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
TypedProperties - Class in org.infinispan.util
Type-aware properties.
TypedProperties(Properties) - Constructor for class org.infinispan.util.TypedProperties
Copy constructor
TypedProperties() - Constructor for class org.infinispan.util.TypedProperties
Default constructor that returns an empty instance

U

uc(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Safely converts a String to upper case.
unblock() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
UnclosableObjectInputStream - Class in org.infinispan.io
A delegating ObjectInput that delegates all methods except ObjectInput.close().
UnclosableObjectInputStream(ObjectInput) - Constructor for class org.infinispan.io.UnclosableObjectInputStream
 
UnclosableObjectOutputStream - Class in org.infinispan.io
An unclosable version of an ObjectOutput.
UnclosableObjectOutputStream(ObjectOutput) - Constructor for class org.infinispan.io.UnclosableObjectOutputStream
 
unlink(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.FIFODataContainer
Un-links an entry from the doubly linked list in a threadsafe, lock-free manner.
unlock(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Release the locks (either read or write).
unlock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases the lock passed in, held by the specified owner
unlock(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases locks present in an invocation context and transaction entry, if one is available.
unlock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
unlock(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
unlock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
unmarshall(Marshaller, InputStream) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
unmarshallArray(ObjectInput, UnmarshalledReferences) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
UnmarshalledReferences - Class in org.infinispan.marshall
An efficient array-based list of referenced objects, using the reference id as a subscript for the array.
UnmarshalledReferences() - Constructor for class org.infinispan.marshall.UnmarshalledReferences
 
unmarshallMap(Map, ObjectInput) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
 
unmarshallObject(ObjectInput, ClassLoader, UnmarshalledReferences, boolean) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
unmarshallObject(ObjectInput, UnmarshalledReferences) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
unmarshallString(ObjectInput) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
unregisterConfiguration(String) - Method in interface org.infinispan.config.ConfigurationRegistry
Unregisters the named configuration.
unregisterMBeans() - Method in class org.infinispan.jmx.CacheJmxRegistration
Unregister when the cache is being stoped.
unregisterMBeans() - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Unregisters all the MBeans registered through ComponentsJmxRegistration.registerMBeans().
unregisterNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
unsetContextFlag(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility method that unsets a context flag.
unsetFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Utility method that sets the value of the flag to false.
UnsignedNumeric - Class in org.infinispan.io
Helper to read and write unsigned numerics
UnsignedNumeric() - Constructor for class org.infinispan.io.UnsignedNumeric
 
UnsuccessfulResponse - Class in org.infinispan.remoting.responses
An unsuccessful response
UnsupportedKeyTypeException - Exception in org.infinispan.loaders.jdbc.stringbased
Exception thrown by JdbcStringBasedCacheStore when one tries to persist a StoredEntry with an unsupported key type.
UnsupportedKeyTypeException(Object) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String, Throwable) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(Throwable) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
update() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
updateLinks(FIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.LRUDataContainer
 
updateLinks(SpinLockBasedFIFODataContainer.LinkedEntry) - Method in class org.infinispan.container.SpinLockBasedLRUDataContainer
Updates links on this entry, moving it to the end of the linked list
useChainingCacheLoader() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
useRefs - Variable in class org.infinispan.marshall.MarshallerImpl
Deprecated.  
Util - Class in org.infinispan.util
General utility methods used throughout the JBC code base.
Util.MapModifications - Class in org.infinispan.util
Static inner class that holds 3 maps - for data added, removed and modified.
Util.MapModifications() - Constructor for class org.infinispan.util.Util.MapModifications
 
utx - Static variable in class org.infinispan.transaction.tm.DummyTransactionManager
 

V

VALIDATING_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.parsing.RootElementBuilder
 
ValidResponse - Class in org.infinispan.remoting.responses
A valid response
ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
 
value - Variable in class org.infinispan.commands.write.RemoveCommand
When not null, value indicates that the entry should only be removed if the key is mapped to this value.
value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
valueOf(String) - Static method in enum org.infinispan.config.Configuration.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.context.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.context.impl.AbstractInvocationContext.ContextFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.eviction.EvictionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.factories.scopes.Scopes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.lifecycle.ComponentStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.loaders.modifications.Modification.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.transport.DistributedSync.SyncResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.tree.NodeKey.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns the enum constant of this type with the specified name.
values() - Method in class org.infinispan.AbstractDelegatingCache
 
values() - Method in class org.infinispan.atomic.AtomicHashMap
 
values() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
values() - Method in class org.infinispan.CacheDelegate
 
values() - Static method in enum org.infinispan.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.infinispan.config.GlobalConfiguration.ShutdownHookBehavior
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.context.Flag
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.context.impl.AbstractInvocationContext.ContextFlag
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.eviction.EvictionStrategy
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.factories.scopes.Scopes
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.lifecycle.ComponentStatus
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.loaders.modifications.Modification.Type
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Method in class org.infinispan.loaders.s3.jclouds.JCloudsBucket
 
values() - Method in interface org.infinispan.loaders.s3.S3Bucket
 
values() - Static method in enum org.infinispan.notifications.cachelistener.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.infinispan.notifications.cachemanagerlistener.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.infinispan.remoting.rpc.ResponseMode
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.remoting.transport.DistributedSync.SyncResponse
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.infinispan.tree.NodeKey.Type
Returns an array containing the constants of this enum type, in the order they're declared.
values - Variable in class org.infinispan.util.AbstractMap
 
values() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
 
values() - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Method in class org.infinispan.util.FastCopyHashMap
 
verifyOrCreateBucket(String) - Method in class org.infinispan.loaders.s3.jclouds.JCloudsConnection
 
verifyOrCreateBucket(String) - Method in interface org.infinispan.loaders.s3.S3Connection
 
Version - Class in org.infinispan
Contains version information about this release of Infinispan.
Version() - Constructor for class org.infinispan.Version
 
version - Static variable in class org.infinispan.Version
 
VersionAwareMarshaller - Class in org.infinispan.marshall
A delegate to various other marshallers like JBossMarshaller.
VersionAwareMarshaller() - Constructor for class org.infinispan.marshall.VersionAwareMarshaller
 
viewAccepted(View) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
viewChange(ViewChangedEvent) - Method in class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
The cluster formation changed, so determine whether the current cache stopped being the coordinator or became the coordinator.
ViewChanged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.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.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with ViewChanged.
viewChangeEvent(ViewChangedEvent) - Method in class org.infinispan.demo.InfinispanDemo.CacheListener
 
visit(E) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Visits the key in the underlying Map, by performing a Map.get(Object).
VisitableBidirectionalLinkedHashSet<E> - Class in org.infinispan.util
Similar to the JDK's LinkedHashSet except that it sets the underlying LinkedHashMap's accessOrder constructor parameter to true, allowing for recording of visits.
VisitableBidirectionalLinkedHashSet(boolean, int, float) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new, empty linked hash set with the specified initial capacity and load factor.
VisitableBidirectionalLinkedHashSet(boolean, int) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new, empty linked hash set with the specified initial capacity and the default load factor (0.75).
VisitableBidirectionalLinkedHashSet(boolean) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new, empty linked hash set with the default initial capacity (16) and load factor (0.75).
VisitableBidirectionalLinkedHashSet(boolean, Collection<? extends E>) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new linked hash set with the same elements as the specified collection.
VisitableCommand - Interface in org.infinispan.commands
A type of command that can accept Visitors, such as CommandInterceptors.
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in interface org.infinispan.commands.Visitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitCollection(InvocationContext, Collection<? extends VisitableCommand>) - Method in class org.infinispan.commands.AbstractVisitor
Helper method to visit a collection of VisitableCommands.
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in interface org.infinispan.commands.Visitor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in interface org.infinispan.commands.Visitor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in interface org.infinispan.commands.Visitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in interface org.infinispan.commands.Visitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
Visitor - Interface in org.infinispan.commands
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in interface org.infinispan.commands.Visitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 

W

waitForState() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
warn(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
warn(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
warn(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
warn(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
warn(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
warn(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
warn(Object) - Method in interface org.infinispan.util.logging.Log
 
warn(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
warn(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
warn(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
wireDependencies(Object) - Method in class org.infinispan.factories.AbstractComponentRegistry
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.
WithinThreadExecutor - Class in org.infinispan.util.concurrent
An executor that works within the current thread.
WithinThreadExecutor() - Constructor for class org.infinispan.util.concurrent.WithinThreadExecutor
 
wrapEntryForReading(InvocationContext, Object) - Method in interface org.infinispan.factories.EntryFactory
 
wrapEntryForReading(InvocationContext, Object) - Method in class org.infinispan.factories.EntryFactoryImpl
 
wrapEntryForWriting(InvocationContext, Object, boolean, boolean, boolean, boolean) - Method in interface org.infinispan.factories.EntryFactory
 
wrapEntryForWriting(InvocationContext, Object, boolean, boolean, boolean, boolean) - Method in class org.infinispan.factories.EntryFactoryImpl
 
wrapMap(Map<Object, Object>, Set<MarshalledValue>, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
write(byte[], int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[]) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
WriteCommand - Interface in org.infinispan.commands.write
A command that modifies the cache in some way
writeCommitLog(Marshaller, ObjectOutput) - Method in class org.infinispan.transaction.TransactionLog
 
writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeExternal(ObjectOutput) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
writeExternal(ObjectOutput) - Method in class org.infinispan.atomic.NullDelta
 
writeExternal(ObjectOutput) - Method in class org.infinispan.atomic.Operation
 
writeExternal(ObjectOutput) - Method in class org.infinispan.atomic.PutOperation
 
writeExternal(ObjectOutput) - Method in class org.infinispan.atomic.RemoveOperation
 
writeExternal(ObjectOutput) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
writeExternal(ObjectOutput) - Method in class org.infinispan.tree.Fqn
 
writeExternal(ObjectOutput) - Method in class org.infinispan.util.ImmutableListCopy
Format: - entry array size (int) - elements (Object)
writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ArrayListExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.BucketExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.DeltaAwareExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ExceptionResponseExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ExtendedResponseExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.GlobalTransactionExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ImmortalCacheEntryExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ImmortalCacheValueExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ImmutableMapExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.JGroupsAddressExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.LinkedListExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.MapExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.MarshalledValueExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.MortalCacheEntryExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.MortalCacheValueExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.ReplicableCommandExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.SetExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.SingletonListExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.SuccessfulResponseExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.TransactionLogExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.TransientCacheEntryExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.TransientCacheValueExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.TransientMortalCacheEntryExternalizer
 
writeObject(Marshaller, Object) - Method in class org.infinispan.marshall.jboss.externalizers.TransientMortalCacheValueExternalizer
 
writePendingPrepares(Marshaller, ObjectOutput) - Method in class org.infinispan.transaction.TransactionLog
 
writeReference(ObjectOutput, int) - Method in class org.infinispan.marshall.MarshallerImpl
Deprecated. This version of writeReference is written to solve JBCACHE-1211, where references are encoded as ints rather than shorts.
writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeUnsignedInt(ObjectOutput, int) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedInt(ObjectOutput, int) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
Writes an int in a variable-length format.
writeUnsignedLong(ObjectOutput, long) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(ObjectOutput, long) - Static method in class org.infinispan.marshall.jboss.MarshallUtil
Writes a long in a variable-length format.
writeUTF(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 

X

xid - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
xmlAttribs - Variable in class org.infinispan.config.parsing.ParsedAttributes
 
XmlConfigHelper - Class in org.infinispan.config.parsing
A simple XML utility class for reading configuration elements
XmlConfigHelper() - Constructor for class org.infinispan.config.parsing.XmlConfigHelper
 
XmlConfigurationParser - Interface in org.infinispan.config.parsing
Implementations of this interface are responsible for parsing XML configuration files.
XmlConfigurationParserImpl - Class in org.infinispan.config.parsing
The default XML configuration parser
XmlConfigurationParserImpl() - Constructor for class org.infinispan.config.parsing.XmlConfigurationParserImpl
Constructs a new parser
XmlConfigurationParserImpl(String) - Constructor for class org.infinispan.config.parsing.XmlConfigurationParserImpl
Constructs a parser and initializes it with the file name passed in, by calling XmlConfigurationParserImpl.initialize(String).
XmlConfigurationParserImpl(InputStream) - Constructor for class org.infinispan.config.parsing.XmlConfigurationParserImpl
Constructs a parser and initializes it with the input stream passed in, by calling XmlConfigurationParserImpl.initialize(InputStream).
XmlParserBase - Class in org.infinispan.config.parsing
Contains utility methods that might be useful to most of the parsers.
XmlParserBase() - Constructor for class org.infinispan.config.parsing.XmlParserBase
 

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

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