A B C D E F G H I J K L M N O P Q 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
 
AbstractConfigurationBeanVisitor - Class in org.infinispan.config
AbstractConfigurationBeanVisitor is a convenience super class for ConfigurationBeanVisitor classes.
AbstractConfigurationBeanVisitor() - Constructor for class org.infinispan.config.AbstractConfigurationBeanVisitor
 
AbstractConsistentHash - Class in org.infinispan.distribution
An abstract consistent hash implementation that handles common implementations of certain methods.
AbstractConsistentHash() - Constructor for class org.infinispan.distribution.AbstractConsistentHash
 
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
 
AbstractDataWriteCommand - Class in org.infinispan.commands.write
Stuff common to WriteCommands
AbstractDataWriteCommand() - Constructor for class org.infinispan.commands.write.AbstractDataWriteCommand
 
AbstractDataWriteCommand(Object) - Constructor for class org.infinispan.commands.write.AbstractDataWriteCommand
 
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
 
AbstractIterator - Class in org.infinispan.query.impl
This is the abstract superclass of the 2 iterators.
AbstractIterator() - Constructor for class org.infinispan.query.impl.AbstractIterator
 
AbstractJmxRegistration - Class in org.infinispan.jmx
Parent class for top level JMX component registration.
AbstractJmxRegistration() - Constructor for class org.infinispan.jmx.AbstractJmxRegistration
 
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
 
AbstractModuleLifecycle - Class in org.infinispan.lifecycle
A default, no-op implementation of the ModuleLifecycle interface, designed for easy extension.
AbstractModuleLifecycle() - Constructor for class org.infinispan.lifecycle.AbstractModuleLifecycle
 
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
 
AbstractTreeWalker - Class in org.infinispan.tools.schema
TreeWalker abstract super class that should be extended for a particular tool
AbstractTreeWalker() - Constructor for class org.infinispan.tools.schema.AbstractTreeWalker
 
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
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.AsyncType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.ClusteringType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.EvictionType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.ExpirationType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.HashType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.L1Type
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.LockingType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.SyncType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.TransactionType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.UnsafeType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.CustomInterceptorConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.InfinispanConfiguration
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
accept(ConfigurationBeanVisitor) - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
accept(TreeWalker) - Method in class org.infinispan.tools.schema.TreeNode
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.control.LockControlCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.EntrySetCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.KeySetCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.SizeCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.ValuesCommand
 
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.container.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.container.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
Attempts to acquire a lock for the given object within certain time boundaries defined by the timeout and time unit parameters.
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(Object) - Method in class org.infinispan.query.impl.EagerIterator
This method is not supported in and should not be called.
add(Object) - Method in class org.infinispan.query.impl.LazyIterator
This method is not supported in and should not be called.
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.
addAffectedKeys(Object...) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAffectedKeys(Object...) - Method in interface org.infinispan.context.impl.TxInvocationContext
Registers a new participant with the transaction.
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
 
addAttribute(XSAttributeDecl) - Method in class org.infinispan.tools.schema.TreeNode
 
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
 
addNewDocument(String) - Method in class org.infinispan.lucenedemo.DemoActions
Creates a new document having just one field containing a string
addOperation(Operation) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
addr - Variable in class org.infinispan.transaction.xa.GlobalTransaction
 
address - Variable in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
Address - Interface in org.infinispan.remoting.transport
A destination for an Infinispan command or operation.
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
addToCache(Influenza_N_P_CR_Element) - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
addToCache(Nucleotide_Protein_Element) - Method in class org.infinispan.ec2demo.NucleotideCache
 
addToCache(Nucleotide_Protein_Element) - Method in class org.infinispan.ec2demo.ProteinCache
 
addToIndexes(Object, Object) - Method in class org.infinispan.query.backend.QueryInterceptor
 
AdvancedCache<K,V> - Interface in org.infinispan
An advanced interface that exposes additional methods not available on Cache.
affectedKeys - Variable in class org.infinispan.context.impl.AbstractTxInvocationContext
 
after - Variable in class org.infinispan.config.CustomInterceptorConfig
 
afterFirst() - Method in class org.infinispan.query.impl.AbstractIterator
 
afterFirst() - Method in interface org.infinispan.query.QueryIterator
Jumps to the one-after-the-first result
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
 
allowDuplicateDomains - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
annotation(XSAnnotation) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
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.cloud.CloudCacheStore
 
applyModifications(List<? extends Modification>) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
applyModificationsSync(ConcurrentMap<Object, Modification>) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
applyOverrides(Configuration) - Method in class org.infinispan.config.Configuration
 
applyReceivedState(Map<Object, InternalCacheValue>) - Method in interface org.infinispan.distribution.DistributionManager
Applies a state map received via a RehashControlCommand.
applyReceivedState(Map<Object, InternalCacheValue>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
applyRemoteTxLog(List<WriteCommand>) - Method in interface org.infinispan.distribution.DistributionManager
Applies an ordered list of modifications to the current node.
applyRemoteTxLog(List<WriteCommand>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
applyState(ConsistentHash, Map<Object, InternalCacheValue>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
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.
ARRAY_LIST - Static variable in interface org.infinispan.marshall.Ids
ids for jdk classes *
ArrayListExternalizer - Class in org.infinispan.marshall.exts
List externalizer dealing with ArrayList and LinkedList implementations.
ArrayListExternalizer() - Constructor for class org.infinispan.marshall.exts.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 - Variable in class org.infinispan.config.Configuration.ClusteringType
 
async - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
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
 
asyncExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
asyncMarshalling - Variable in class org.infinispan.config.Configuration.AsyncType
 
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
 
ATOMIC_CLEAR_OPERATION - Static variable in interface org.infinispan.marshall.Ids
 
ATOMIC_HASH_MAP - Static variable in interface org.infinispan.marshall.Ids
 
ATOMIC_HASH_MAP_DELTA - Static variable in interface org.infinispan.marshall.Ids
 
ATOMIC_PUT_OPERATION - Static variable in interface org.infinispan.marshall.Ids
 
ATOMIC_REMOVE_OPERATION - Static variable in interface org.infinispan.marshall.Ids
 
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
 
AtomicHashMap.Externalizer - Class in org.infinispan.atomic
 
AtomicHashMap.Externalizer() - Constructor for class org.infinispan.atomic.AtomicHashMap.Externalizer
 
AtomicHashMapDelta - Class in org.infinispan.atomic
Changes that have occurred on an AtomicHashMap
AtomicHashMapDelta() - Constructor for class org.infinispan.atomic.AtomicHashMapDelta
 
AtomicHashMapDelta.Externalizer - Class in org.infinispan.atomic
 
AtomicHashMapDelta.Externalizer() - Constructor for class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
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.
AtomicMapLookup - Class in org.infinispan.atomic
A helper that locates atomic maps within a given cache.
AtomicMapLookup() - Constructor for class org.infinispan.atomic.AtomicMapLookup
 
attachGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.control.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
 
attGroupDecl(XSAttGroupDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
attributeDecl(XSAttributeDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
attributes - Variable in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
attributeUse(XSAttributeUse) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
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
 
BaseRpcCommand(String) - Constructor for class org.infinispan.commands.remote.BaseRpcCommand
 
BaseRpcCommand() - Constructor for class org.infinispan.commands.remote.BaseRpcCommand
 
BaseRpcInterceptor - Class in org.infinispan.interceptors.base
Acts as a base for all RPC calls
BaseRpcInterceptor() - Constructor for class org.infinispan.interceptors.base.BaseRpcInterceptor
 
BaseRpcInvokingCommand - Class in org.infinispan.commands.remote
Base class for RPC commands.
BaseRpcInvokingCommand(String) - Constructor for class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
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
 
BeanConventions - Class in org.infinispan.tools
BeanConventions.
BeanConventions() - Constructor for class org.infinispan.tools.BeanConventions
 
BeanUtils - Class in org.infinispan.util
Simple JavaBean manipulation helper methods
BeanUtils() - Constructor for class org.infinispan.util.BeanUtils
 
before - Variable in class org.infinispan.config.CustomInterceptorConfig
 
beforeLast() - Method in class org.infinispan.query.impl.AbstractIterator
 
beforeLast() - Method in interface org.infinispan.query.QueryIterator
Jumps to the one-before-the-last result
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 navigated 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
 
BUCKET - Static variable in interface org.infinispan.marshall.Ids
 
Bucket.Externalizer - Class in org.infinispan.loaders.bucket
 
Bucket.Externalizer() - Constructor for class org.infinispan.loaders.bucket.Bucket.Externalizer
 
BucketBasedCacheStore - Class in org.infinispan.loaders.bucket
Base class for CacheStore implementations that combine entries into buckets when storing data.
BucketBasedCacheStore() - Constructor for class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
buffer - Variable in class org.infinispan.query.impl.AbstractIterator
 
BufferedConcurrentHashMap<K,V> - Class in org.infinispan.util.concurrent
A hash table supporting full concurrency of retrievals and adjustable expected concurrency for updates.
BufferedConcurrentHashMap(int, float, int, BufferedConcurrentHashMap.Eviction, BufferedConcurrentHashMap.EvictionListener<K, V>) - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Creates a new, empty map with the specified initial capacity, load factor and concurrency level.
BufferedConcurrentHashMap(int, float, int) - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
 
BufferedConcurrentHashMap(int, float, int, BufferedConcurrentHashMap.Eviction) - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
 
BufferedConcurrentHashMap(int, float) - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Creates a new, empty map with the specified initial capacity and load factor and with the default concurrencyLevel (16).
BufferedConcurrentHashMap(int) - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Creates a new, empty map with the specified initial capacity, and with default load factor (0.75) and concurrencyLevel (16).
BufferedConcurrentHashMap() - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Creates a new, empty map with a default initial capacity (16), load factor (0.75) and concurrencyLevel (16).
BufferedConcurrentHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Creates a new map with the same mappings as the given map.
BufferedConcurrentHashMap.Eviction - Enum in org.infinispan.util.concurrent
 
BufferedConcurrentHashMap.EvictionListener<K,V> - Interface in org.infinispan.util.concurrent
 
BufferedConcurrentHashMap.EvictionPolicy<K,V> - Interface in org.infinispan.util.concurrent
 
bufferIndex - Variable in class org.infinispan.query.impl.AbstractIterator
 
buildClearCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClearCommand
buildClearCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command
buildClusteredGetCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CommitCommand
buildCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEntrySetCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a EntrySetCommand
buildEntrySetCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEvictCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
Builds an EvictCommand
buildEvictCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetKeyValueCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
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
Builds an InvalidateCommand
buildInvalidateCommand(Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(boolean, Object...) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateFromL1Command
buildInvalidateFromL1Command(boolean, Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildKeySetCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a KeySetCommand
buildKeySetCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a LockControlCommand to control explicit remote locking
buildLockControlCommand(Collection, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PrepareCommand
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutKeyValueCommand(Object, Object, long, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutKeyValueCommand
buildPutKeyValueCommand(Object, Object, long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map, long, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutMapCommand
buildPutMapCommand(Map, long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRegistrar(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
buildRegistrar(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
buildRegistrar(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
buildRehashControlCommand(RehashControlCommand.Type, Address) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
buildRehashControlCommand(Address, Map<Object, InternalCacheValue>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
buildRehashControlCommand(RehashControlCommand.Type, Address, Map<Object, InternalCacheValue>, ConsistentHash) - Method in interface org.infinispan.commands.CommandsFactory
A more generic version of this factory method that allows the setting of various fields.
buildRehashControlCommand(RehashControlCommand.Type, Address) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRehashControlCommand(Address, Map<Object, InternalCacheValue>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRehashControlCommand(RehashControlCommand.Type, Address, Map<Object, InternalCacheValue>, ConsistentHash) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRehashControlCommandTxLog(Address, List<WriteCommand>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
buildRehashControlCommandTxLog(Address, List<WriteCommand>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRehashControlCommandTxLogPendingPrepares(Address, List<PrepareCommand>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
buildRehashControlCommandTxLogPendingPrepares(Address, List<PrepareCommand>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveCommand(Object, Object) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RemoveCommand
buildRemoveCommand(Object, Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplaceCommand(Object, Object, Object, long, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplicateCommand(List<ReplicableCommand>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an RpcCommand "envelope" containing multiple ReplicableCommands
buildReplicateCommand(List<ReplicableCommand>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRollbackCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RollbackCommand
buildRollbackCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleRpcCommand(ReplicableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
buildSingleRpcCommand(ReplicableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSizeCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a SizeCommand
buildSizeCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferControlCommand(boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a StateTransferControlCommand
buildStateTransferControlCommand(boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildValuesCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a ValuesCommand
buildValuesCommand() - 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

c - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
Cache<K,V> - Interface in org.infinispan
The central interface of Infinispan.
cache - Variable in class org.infinispan.loaders.AbstractCacheStore
 
cache - Variable in class org.infinispan.query.impl.AbstractIterator
 
cache - Variable in class org.infinispan.tree.TreeStructureSupport
 
CACHE_NAME_FOR_INDEXES - Static variable in class org.infinispan.lucenedemo.DirectoryFactory
 
CACHE_NAME_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
CacheBuilder - Class in org.infinispan.ec2demo
 
CacheBuilder(String) - Constructor for class org.infinispan.ec2demo.CacheBuilder
 
CacheComponent - Class in org.infinispan.jopr
Component class for Caches within Infinispan
CacheComponent() - Constructor for class org.infinispan.jopr.CacheComponent
 
CacheDelegate<K,V> - Class in org.infinispan
 
CacheDelegate(String) - Constructor for class org.infinispan.CacheDelegate
 
CacheDiscovery - Class in org.infinispan.jopr
Discovery class for individual cache instances
CacheDiscovery() - Constructor for class org.infinispan.jopr.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 subtype 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 subtype is passed in to any method annotated with CacheEntryCreated.
CacheEntryEvent - Interface in org.infinispan.notifications.cachelistener.event
A transactional event subtype 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 subtype 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 subtype 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 subtype is passed in to any method annotated with CacheEntryModified

The CacheEntryModifiedEvent.getValue() method's behavior is specific to whether the callback is triggered before or after the event in question.

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 subtype 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 subtype 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 subtype 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
 
CacheKey - Interface in org.infinispan.lucene
Interface for objects used as a key for Infinispan cache.
CacheLoader - Interface in org.infinispan.loaders
Responsible for loading cache data from an external source
cacheLoaderClassName - Variable in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
CacheLoaderConfig - Interface in org.infinispan.loaders
Configures individual cache loaders
cacheLoaderConfigs - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
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.
CacheManagerComponent - Class in org.infinispan.jopr
The component class for the Infinispan manager
CacheManagerComponent() - Constructor for class org.infinispan.jopr.CacheManagerComponent
 
CacheManagerDiscovery - Class in org.infinispan.jopr
Discovery class for Infinispan engines
CacheManagerDiscovery() - Constructor for class org.infinispan.jopr.CacheManagerDiscovery
 
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
 
cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStarted(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStopped(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStopped(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStopping(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStopping(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
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
 
CacheQuery - Interface in org.infinispan.query
A cache-query is what will be returned when the getQuery() method is run on QueryFactory.
CacheQueryImpl - Class in org.infinispan.query.impl
Implementation class of the CacheQuery interface.
CacheQueryImpl(Query, SearchFactoryImplementor, Cache, Class...) - Constructor for class org.infinispan.query.impl.CacheQueryImpl
 
CacheRpcCommand - Interface in org.infinispan.commands.remote
The RpcManager only replicates commands wrapped in a CacheRpcCommand.
CacheSearchServlet - Class in org.infinispan.ec2demo.web
Servlet implementation class CacheSearchServlet
CacheSearchServlet() - Constructor for class org.infinispan.ec2demo.web.CacheSearchServlet
 
CacheServletListener - Class in org.infinispan.ec2demo.web
 
CacheServletListener() - Constructor for class org.infinispan.ec2demo.web.CacheServletListener
 
cacheSizes() - Method in class org.infinispan.ec2demo.InfluenzaDataLoader
 
cacheStarted(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStarted(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
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.
cacheStarted(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStarted.
cacheStarting(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStarting(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStopped(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
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.
cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
CacheStoppedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStopped.
cacheStopping(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStopping(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
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.
call() - Method in class org.infinispan.distribution.RehashTask
 
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
 
canExpire() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
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
 
channel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CHANNEL_LOOKUP - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
checkStatisticsUsed() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
classes - Variable in class org.infinispan.query.backend.SearchableCacheConfiguration
 
ClassFinder - Class in org.infinispan.util
Find infinispan classes utility
ClassFinder() - Constructor for class org.infinispan.util.ClassFinder
 
className - Variable in class org.infinispan.config.CustomInterceptorConfig
 
className - Variable in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
cleanup() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
clear() - Method in class org.infinispan.AbstractDelegatingCache
 
clear() - Method in class org.infinispan.atomic.AtomicHashMap
 
clear() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
clear() - 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.loaders.bdbje.BdbjeCacheStore
Clears all entries in the store
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.DataManipulationHelper
 
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.util.BidirectionalLinkedHashMap
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Removes all of the mappings from this map.
clear() - Method in interface org.infinispan.util.concurrent.BufferedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that all Segment entries have been cleared.
clear() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.infinispan.util.FastCopyHashMap
 
clear() - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
clear() - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
clear() - Method in class org.infinispan.util.FastCopyHashMap.Values
 
clear() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Removes all of the elements from this set.
CLEAR_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
clearAsync() - Method in class org.infinispan.AbstractDelegatingCache
 
clearAsync() - Method in interface org.infinispan.Cache
Asynchronous version of Map.clear().
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
 
clearLock(String) - Method in class org.infinispan.lucene.locking.LuceneLockFactory
clearLockSafe() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
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
 
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
An atomic clear operation.
ClearOperation.Externalizer - Class in org.infinispan.atomic
 
ClearOperation.Externalizer() - Constructor for class org.infinispan.atomic.ClearOperation.Externalizer
 
clm - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
clone() - Method in class org.infinispan.config.AbstractConfigurationBean
 
clone() - Method in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
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.Configuration.ClusteringType
 
clone() - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
 
clone() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
clone() - Method in class org.infinispan.config.CustomInterceptorConfig
 
clone() - Method in class org.infinispan.config.GlobalConfiguration
 
clone() - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
 
clone() - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
 
clone() - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
 
clone() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
clone() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
clone() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
clone() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.MortalCacheValue
 
clone() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
clone() - Method in class org.infinispan.container.entries.TransientCacheValue
 
clone() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
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.factories.AbstractComponentRegistry
 
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.mixed.JdbcMixedCacheStoreConfig
 
clone() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
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.lucene.InfinispanDirectory
close() - Method in class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexInput
 
close() - Method in class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexOutput
 
close() - Static method in class org.infinispan.lucenedemo.DirectoryFactory
 
close() - Method in class org.infinispan.query.impl.EagerIterator
 
close() - Method in class org.infinispan.query.impl.LazyIterator
 
close() - Method in interface org.infinispan.query.QueryIterator
This method must be called on your iterator once you have finished so that Lucene resources can be freed up.
close() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
closeConnection() - Method in class org.infinispan.jopr.ConnectionHelper
If necessary attempt to close the EMS connection, then set this.connection null.
closeInput(ObjectInput) - Static method in class org.infinispan.util.Util
 
closeSearcher(Searcher, ReaderProvider) - Static method in class org.infinispan.query.backend.IndexSearcherCloser
 
closeStream(InputStream) - Static method in class org.infinispan.util.Util
 
CloudCacheStore - Class in org.infinispan.loaders.cloud
The CloudCacheStore implementation that utilizes JClouds to communicate with cloud storage providers such as Amazon's S3, Rackspace's Cloudfiles, or any other such provider supported by JClouds.
CloudCacheStore() - Constructor for class org.infinispan.loaders.cloud.CloudCacheStore
 
CloudCacheStoreConfig - Class in org.infinispan.loaders.cloud
The cache store config bean for the CloudCacheStore.
CloudCacheStoreConfig() - Constructor for class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
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
 
CLUSTERED_GET_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
ClusteredGetCommand - Class in org.infinispan.commands.remote
Issues a remote get call.
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
 
clusterName - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
 
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.LockControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.control.RehashControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.control.StateTransferControlCommand
 
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
A factory to build commands, initializing and injecting dependencies accordingly.
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.
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.AsyncStore
 
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 - Class in org.infinispan.loaders.modifications
Commit.
Commit(GlobalTransaction) - Constructor for class org.infinispan.loaders.modifications.Commit
 
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
 
COMMIT_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
CommitCommand - Class in org.infinispan.commands.tx
Command corresponding to the 2nd phase of 2PC.
CommitCommand(GlobalTransaction) - Constructor for class org.infinispan.commands.tx.CommitCommand
 
CommitCommand() - Constructor for class org.infinispan.commands.tx.CommitCommand
 
commitEntry(CacheEntry) - Method in class org.infinispan.interceptors.DistLockingInterceptor
 
commitEntry(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(ExperimentalDefaultConsistentHash.Entry) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
Compare this Entry with another Entry.
compareTo(JmxComponent) - Method in class org.infinispan.tools.doclet.jmx.JmxComponent
 
compareTo(TreeNode) - Method in class org.infinispan.tools.schema.TreeNode
 
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.
complexType(XSComplexType) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
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.
concurrencyLevel - Variable in class org.infinispan.config.Configuration.LockingType
 
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
 
ConfigDoclet - Class in org.infinispan.tools.doclet.config
A Doclet that generates configuration guide for Infinispan
ConfigDoclet() - Constructor for class org.infinispan.tools.doclet.config.ConfigDoclet
 
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
 
ConfigHtmlGenerator - Class in org.infinispan.tools.doclet.config
Infinispan configuration reference guide generator
ConfigHtmlGenerator(String, String, String, String, String, String, List<String>, String) - Constructor for class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
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.AsyncType - Class in org.infinispan.config
 
Configuration.BooleanAttributeType - Class in org.infinispan.config
 
Configuration.BooleanAttributeType() - Constructor for class org.infinispan.config.Configuration.BooleanAttributeType
 
Configuration.BooleanAttributeType(String) - Constructor for class org.infinispan.config.Configuration.BooleanAttributeType
 
Configuration.CacheMode - Enum in org.infinispan.config
Cache replication mode.
Configuration.ClusteringType - Class in org.infinispan.config
 
Configuration.ClusteringType() - Constructor for class org.infinispan.config.Configuration.ClusteringType
 
Configuration.ClusteringTypeAdapter - Class in org.infinispan.config
 
Configuration.ClusteringTypeAdapter() - Constructor for class org.infinispan.config.Configuration.ClusteringTypeAdapter
 
Configuration.CustomInterceptorsType - Class in org.infinispan.config
 
Configuration.CustomInterceptorsType() - Constructor for class org.infinispan.config.Configuration.CustomInterceptorsType
 
Configuration.DeadlockDetectionType - Class in org.infinispan.config
 
Configuration.DeadlockDetectionType() - Constructor for class org.infinispan.config.Configuration.DeadlockDetectionType
 
Configuration.EvictionType - Class in org.infinispan.config
 
Configuration.EvictionType() - Constructor for class org.infinispan.config.Configuration.EvictionType
 
Configuration.ExpirationType - Class in org.infinispan.config
 
Configuration.ExpirationType() - Constructor for class org.infinispan.config.Configuration.ExpirationType
 
Configuration.HashType - Class in org.infinispan.config
 
Configuration.HashType() - Constructor for class org.infinispan.config.Configuration.HashType
 
Configuration.InvocationBatching - Class in org.infinispan.config
 
Configuration.InvocationBatching() - Constructor for class org.infinispan.config.Configuration.InvocationBatching
 
Configuration.JmxStatistics - Class in org.infinispan.config
 
Configuration.JmxStatistics() - Constructor for class org.infinispan.config.Configuration.JmxStatistics
 
Configuration.L1Type - Class in org.infinispan.config
 
Configuration.L1Type() - Constructor for class org.infinispan.config.Configuration.L1Type
 
Configuration.LazyDeserialization - Class in org.infinispan.config
 
Configuration.LazyDeserialization() - Constructor for class org.infinispan.config.Configuration.LazyDeserialization
 
Configuration.LockingType - Class in org.infinispan.config
 
Configuration.LockingType() - Constructor for class org.infinispan.config.Configuration.LockingType
 
Configuration.QueryConfigurationBean - Class in org.infinispan.config
 
Configuration.QueryConfigurationBean() - Constructor for class org.infinispan.config.Configuration.QueryConfigurationBean
 
Configuration.StateRetrievalType - Class in org.infinispan.config
 
Configuration.StateRetrievalType() - Constructor for class org.infinispan.config.Configuration.StateRetrievalType
 
Configuration.SyncType - Class in org.infinispan.config
 
Configuration.SyncType() - Constructor for class org.infinispan.config.Configuration.SyncType
 
Configuration.TransactionType - Class in org.infinispan.config
 
Configuration.TransactionType(String) - Constructor for class org.infinispan.config.Configuration.TransactionType
 
Configuration.TransactionType() - Constructor for class org.infinispan.config.Configuration.TransactionType
 
Configuration.UnsafeType - Class in org.infinispan.config
 
Configuration.UnsafeType() - Constructor for class org.infinispan.config.Configuration.UnsafeType
 
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
 
ConfigurationBeanVisitor - Interface in org.infinispan.config
ConfigurationBeanVisitor implementations are passed through InfinispanConfiguration object tree visiting each configuration element of InfinispanConfiguration instance.
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.
ConfigurationValidatingVisitor - Class in org.infinispan.config
ConfigurationValidatingVisitor checks semantic validity of InfinispanConfiguration instance.
ConfigurationValidatingVisitor() - Constructor for class org.infinispan.config.ConfigurationValidatingVisitor
 
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
Shared helper class to connect to a remote server
ConnectionHelper() - Constructor for class org.infinispan.jopr.ConnectionHelper
 
ConsistentHash - Interface in org.infinispan.distribution
A consistent hash algorithm implementation.
consistentHashClass - Variable in class org.infinispan.config.Configuration.HashType
 
ConsistentHashHelper - Class in org.infinispan.distribution
A helper class that handles the construction of consistent hash instances based on configuration.
ConsistentHashHelper() - Constructor for class org.infinispan.distribution.ConsistentHashHelper
 
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() - 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
 
containRemoteTx(GlobalTransaction) - Method in class org.infinispan.transaction.xa.TransactionTable
 
contains(Object) - Method in class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
contains(Object) - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
contains(Object) - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
contains(Object) - Method in class org.infinispan.util.FastCopyHashMap.Values
 
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) - Method in class org.infinispan.AbstractDelegatingCache
 
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) - 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.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.concurrent.BufferedConcurrentHashMap
Tests if the specified object is a key in this table.
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.concurrent.BufferedConcurrentHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
contentType - Variable in class org.infinispan.remoting.MIMECacheEntry
The MIME Content type value, for example application/octet-stream.
contextDestroyed(ServletContextEvent) - Method in class org.infinispan.ec2demo.web.CacheServletListener
 
contextFlags - Variable in class org.infinispan.context.impl.AbstractInvocationContext
 
contextInitialized(ServletContextEvent) - Method in class org.infinispan.ec2demo.web.CacheServletListener
 
coordinator() - Method in class org.infinispan.distribution.RehashTask
 
coordinator - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
copy() - Method in class org.infinispan.commands.tx.PrepareCommand
 
copy() - Method in class org.infinispan.io.ByteBuffer
 
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
 
createAsyncProcessor() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
createCache(String) - Method in class org.infinispan.ec2demo.InfluenzaDataLoader
 
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).
createConsistentHash(Configuration, List<Address>) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
createConsistentHash(Configuration, List<Address>, Address...) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
createConsistentHash(Configuration, List<Address>, Collection<Address>) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new consistent hash instance based on the user's configuration, and populates the consistent hash with the collection of addresses passed in.
createConsistentHash(Class<? extends ConsistentHash>, List<Address>) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new consistent hash instance based on the type specified, and populates the consistent hash with the collection of addresses passed in.
createConsistentHash(Class<? extends ConsistentHash>, List<Address>, Address...) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new consistent hash instance based on the type specified, and populates the consistent hash with the collection of addresses passed in.
createConsistentHash(Class<? extends ConsistentHash>, List<Address>, Collection<Address>) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new consistent hash instance based on the type specified, and populates the consistent hash with the collection of addresses passed in.
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.
createdChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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.
createInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.factories.InterceptorChainFactory
 
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
 
createNewEntry(Object, Object, long, long) - Method in class org.infinispan.container.entries.InternalEntryFactory
 
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
 
createOutput(String) - Method in class org.infinispan.lucene.InfinispanDirectory
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.
createRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.TransactionTable
Creates and register a RemoteTransaction with no modifications.
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() - Constructor for class org.infinispan.config.CustomInterceptorConfig
 
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.

D

data - Variable in class org.infinispan.remoting.MIMECacheEntry
The payload.
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
 
DataManipulationHelper - Class in org.infinispan.loaders.jdbc
The purpose of this class is to factorize the repeating code between JdbcStringBasedCacheStore and JdbcBinaryCacheStore.
DataManipulationHelper(ConnectionFactory, TableManipulation, Marshaller) - Constructor for class org.infinispan.loaders.jdbc.DataManipulationHelper
 
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
 
DEADLOCK_DETECTING_GLOBAL_TRANSACTION - Static variable in interface org.infinispan.marshall.Ids
 
DeadlockDetectedException - Exception in org.infinispan.util.concurrent.locks
Exception signaling detected deadlocks.
DeadlockDetectedException(String) - Constructor for exception org.infinispan.util.concurrent.locks.DeadlockDetectedException
 
DeadlockDetectingGlobalTransaction - Class in org.infinispan.transaction.xa
This class is used when deadlock detection is enabled.
DeadlockDetectingGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
DeadlockDetectingGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
 
DeadlockDetectingGlobalTransaction.Externalizer() - Constructor for class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction.Externalizer
 
DeadlockDetectingInterceptor - Class in org.infinispan.interceptors
This interceptor populates the DeadlockDetectingGlobalTransaction with appropriate information needed in order to accomplish deadlock detection.
DeadlockDetectingInterceptor() - Constructor for class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
DeadlockDetectingLockManager - Class in org.infinispan.util.concurrent.locks
Lock manager in charge with processing deadlock detections.
DeadlockDetectingLockManager() - Constructor for class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
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_BUFFER_SIZE - Static variable in class org.infinispan.lucene.InfinispanIndexIO
 
DEFAULT_CACHE_NAME - Static variable in class org.infinispan.manager.DefaultCacheManager
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
DEFAULT_CONSISTENT_HASH - Static variable in interface org.infinispan.marshall.Ids
 
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_JGROUPS_CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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.
DefaultCacheManager(String, String, String, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the two configuration file names passed in.
defaultConfiguration - Variable in class org.infinispan.manager.DefaultCacheManager
 
DefaultConsistentHash - Class in org.infinispan.distribution
 
DefaultConsistentHash() - Constructor for class org.infinispan.distribution.DefaultConsistentHash
 
DefaultConsistentHash.Externalizer - Class in org.infinispan.distribution
 
DefaultConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.DefaultConsistentHash.Externalizer
 
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
 
DefaultTransformer - Class in org.infinispan.query
Warning, slow as a dog, uses serialization to get a byte representation of a class.
DefaultTransformer() - Constructor for class org.infinispan.query.DefaultTransformer
 
defaultVisit(AbstractConfigurationBean) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
defineConfiguration(String, Configuration) - Method in interface org.infinispan.manager.CacheManager
Defines a named cache's configuration using the following algorithm:

If cache name hasn't been defined before, this method creates a clone of the default cache's configuration, applies a clone of the configuration overrides passed in and returns this configuration instance.

defineConfiguration(String, String, Configuration) - Method in interface org.infinispan.manager.CacheManager
Defines a named cache's configuration using the following algorithm:

Regardless of whether the cache name has been defined or not, this method creates a clone of the configuration of the cache whose name matches the given template cache name, then applies a clone of the configuration overrides passed in and finally returns this configuration instance.

defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
Defines a named cache's configuration using the following algorithm:

If cache name hasn't been defined before, this method creates a clone of the default cache's configuration, applies a clone of the configuration overrides passed in and returns this configuration instance.

defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
Defines a named cache's configuration using the following algorithm:

Regardless of whether the cache name has been defined or not, this method creates a clone of the configuration of the cache whose name matches the given template cache name, then applies a clone of the configuration overrides passed in and finally returns this configuration instance.

deleteFile(String) - Method in class org.infinispan.lucene.InfinispanDirectory
delistResource(XAResource, int) - Method in class org.infinispan.transaction.tm.DummyTransaction
De-list 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.
DemoActions - Class in org.infinispan.lucenedemo
DemoActions does some basic operations on the Lucene index, to be used by DemoDriver to show base operations on Lucene.
DemoActions() - Constructor for class org.infinispan.lucenedemo.DemoActions
 
DemoActions(InfinispanDirectory) - Constructor for class org.infinispan.lucenedemo.DemoActions
 
DemoDriver - Class in org.infinispan.lucenedemo
DemoDriver is a console hello-world application to show the Lucene clustering capabilities.
DemoDriver() - Constructor for class org.infinispan.lucenedemo.DemoDriver
 
desc - Variable in class org.infinispan.tools.doclet.jmx.JmxComponent
 
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
 
detach() - Method in class org.infinispan.tools.schema.TreeNode
 
detectScope(Class) - Static method in class org.infinispan.factories.scopes.ScopeDetector
 
differentiator - Variable in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
DirectoryFactory - Class in org.infinispan.lucenedemo
Utility to create an InfinispanDirectory for the demo.
DirectoryFactory() - Constructor for class org.infinispan.lucenedemo.DirectoryFactory
 
disableFullTextFilter(String) - Method in interface org.infinispan.query.CacheQuery
Disable a given filter by its name.
disableFullTextFilter(String) - Method in class org.infinispan.query.impl.CacheQueryImpl
Disable a given filter by its name.
discoverResources(ResourceDiscoveryContext<CacheManagerComponent>) - Method in class org.infinispan.jopr.CacheDiscovery
Run the discovery
discoverResources(ResourceDiscoveryContext<CacheManagerComponent>) - Method in class org.infinispan.jopr.CacheManagerDiscovery
Run the discovery
DistCacheStoreInterceptor - Class in org.infinispan.interceptors
Cache store interceptor specific for the distribution cache mode.
DistCacheStoreInterceptor() - Constructor for class org.infinispan.interceptors.DistCacheStoreInterceptor
 
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
 
distributedSyncTimeout - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
 
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.
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.infinispan.ec2demo.web.CacheSearchServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.infinispan.ec2demo.web.CacheSearchServlet
 
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

drain() - Method in interface org.infinispan.distribution.TransactionLogger
Drains the transaction log and returns a list of what has been drained.
drain() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
drainAndLock() - Method in interface org.infinispan.distribution.TransactionLogger
Similar to TransactionLogger.drain() except that relevant locks are acquired so that no more commands are added to the transaction log during this process, and transaction logging is disabled after draining.
drainAndLock() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
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

EagerIterator - Class in org.infinispan.query.impl
This is the implementation class for the interface QueryResultIterator which extends ListIterator.
EagerIterator(List<Object>, Cache, int) - Constructor for class org.infinispan.query.impl.EagerIterator
 
elementDecl(XSElementDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
elements() - Method in class org.infinispan.util.concurrent.BufferedConcurrentHashMap
Returns an enumeration of the values in this table.
empty(XSContentType) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
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
 
enable() - Method in interface org.infinispan.distribution.TransactionLogger
Enables transaction logging
enable() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
enabled - Variable in class org.infinispan.config.Configuration.BooleanAttributeType
 
enabled - Variable in class org.infinispan.config.Configuration.DeadlockDetectionType
 
enabled - Variable in class org.infinispan.config.Configuration.L1Type
 
enabled - Variable in class org.infinispan.config.Configuration.QueryConfigurationBean
 
enabled - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
enabled - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
enabled - Variable in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
enableFullTextFilter(String) - Method in interface org.infinispan.query.CacheQuery
Enable a given filter by its name.
enableFullTextFilter(String) - Method in class org.infinispan.query.impl.CacheQueryImpl
Enable a given filter by its name.
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.container
A factory for constructing MVCCEntry instances for use in the InvocationContext.
EntryFactoryImpl - Class in org.infinispan.container
 
EntryFactoryImpl() - Constructor for class org.infinispan.container.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 interface org.infinispan.Cache
Returns a set view of the mappings contained in this cache.
entrySet() - Method in class org.infinispan.CacheDelegate
 
entrySet() - Method in interface org.infinispan.container.DataContainer
Returns a mutable set of immutable cache entries exposed as immutable Map.Entry instances.
entrySet() - Method in class org.infinispan.container.FIFODataContainer
 
entrySet() - Method in class org.infinispan.container.SimpleDataContainer
 
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.concurrent.BufferedConcurrentHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.infinispan.util.FastCopyHashMap
 
EntrySetCommand - Class in org.infinispan.commands.read
EntrySetCommand.
EntrySetCommand(DataContainer) - Constructor for class org.infinispan.commands.read.EntrySetCommand
 
eq(Object, Object) - Static method in class org.infinispan.util.AbstractMap
 
equals(Object) - Method in class org.infinispan.commands.control.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.InvalidateCommand
 
equals(Object) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
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.AsyncType
 
equals(Object) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
 
equals(Object) - Method in class org.infinispan.config.Configuration.ClusteringType
 
equals(Object) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
 
equals(Object) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
 
equals(Object) - Method in class org.infinispan.config.Configuration
 
equals(Object) - Method in class org.infinispan.config.Configuration.EvictionType
 
equals(Object) - Method in class org.infinispan.config.Configuration.ExpirationType
 
equals(Object) - Method in class org.infinispan.config.Configuration.HashType
 
equals(Object) - Method in class org.infinispan.config.Configuration.L1Type
 
equals(Object) - Method in class org.infinispan.config.Configuration.LockingType
 
equals(Object) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
equals(Object) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
equals(Object) - Method in class org.infinispan.config.Configuration.SyncType
 
equals(Object) - Method in class org.infinispan.config.Configuration.TransactionType
 
equals(Object) - Method in class org.infinispan.config.Configuration.UnsafeType
 
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.container.entries.ImmortalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
equals(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
equals(Object) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
equals(Object) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
equals(Object) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
equals(Object) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
equals(Object) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
equals(Object) - Method in class org.infinispan.loaders.modifications.Commit
 
equals(Object) - Method in class org.infinispan.loaders.modifications.Prepare
 
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.lucene.FileCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileMetadata
 
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.tools.doclet.jmx.JmxComponent
 
equals(Object) - Method in class org.infinispan.tools.schema.TreeNode
 
equals(Object) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
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>, List<Address>, Address, int) - 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
 
EVICT_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
EvictCommand - Class in org.infinispan.commands.write
 
EvictCommand(Object, CacheNotifier) - Constructor for class org.infinispan.commands.write.EvictCommand
 
evicted(K, V) - Method in interface org.infinispan.util.concurrent.BufferedConcurrentHashMap.EvictionListener
 
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
EXCEPTION_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
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
 
ExceptionResponse.Externalizer - Class in org.infinispan.remoting.responses
 
ExceptionResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
execute() - Method in interface org.infinispan.util.concurrent.BufferedConcurrentHashMap.EvictionPolicy
Invokes eviction policy algorithm and returns set of evicted entries.
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
 
ExperimentalDefaultConsistentHash - Class in org.infinispan.distribution
Consistent hashing algorithm.
ExperimentalDefaultConsistentHash() - Constructor for class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
ExperimentalDefaultConsistentHash.Entry - Class in org.infinispan.distribution
An entry into a consistent hash.
ExperimentalDefaultConsistentHash.Entry(Address, String, int, int) - Constructor for class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
ExperimentalDefaultConsistentHash.Externalizer - Class in org.infinispan.distribution
 
ExperimentalDefaultConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Externalizer
 
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.
exposeJmxStats - Variable in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
EXTENDED_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
ExtendedResponse - Class in org.infinispan.remoting.responses
A response with extended information
ExtendedResponse(Response, boolean) - Constructor for class org.infinispan.remoting.responses.ExtendedResponse
 
ExtendedResponse.Externalizer - Class in org.infinispan.remoting.responses
 
ExtendedResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.ExtendedResponse.Externalizer
 
Externalizer - Interface in org.infinispan.marshall
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

facet(XSFacet) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
factory - Variable in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
 
factory - Variable in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
 
FASTCOPY_HASH_MAP - Static variable in interface org.infinispan.marshall.Ids
 
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
 
FastCopyHashMap.EntrySet - Class in org.infinispan.util
 
FastCopyHashMap.EntrySet() - Constructor for class org.infinispan.util.FastCopyHashMap.EntrySet
 
FastCopyHashMap.KeySet - Class in org.infinispan.util
 
FastCopyHashMap.KeySet() - Constructor for class org.infinispan.util.FastCopyHashMap.KeySet
 
FastCopyHashMap.Values - Class in org.infinispan.util
 
FastCopyHashMap.Values() - Constructor for class org.infinispan.util.FastCopyHashMap.Values
 
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
 
fetchInMemoryState - Variable in class org.infinispan.config.Configuration.StateRetrievalType
 
fetchPersistentState - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
fetchSize - Variable in class org.infinispan.query.impl.AbstractIterator
 
fieldName - Variable in class org.infinispan.config.Configuration.BooleanAttributeType
 
FIFODataContainer - Class in org.infinispan.container
A container that maintains order of entries based on when they were placed in the container.
FIFODataContainer(int) - Constructor for class org.infinispan.container.FIFODataContainer
 
FIFODataContainer.EntryIterator - Class in org.infinispan.container
 
FIFODataContainer.EntryIterator() - Constructor for class org.infinispan.container.FIFODataContainer.EntryIterator
 
FIFODataContainer.EntrySet - Class in org.infinispan.container
 
FIFODataContainer.EntrySet() - Constructor for class org.infinispan.container.FIFODataContainer.EntrySet
 
FIFODataContainer.ImmutableEntryIterator - Class in org.infinispan.container
 
FIFODataContainer.ImmutableEntryIterator() - Constructor for class org.infinispan.container.FIFODataContainer.ImmutableEntryIterator
 
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
 
FIFODataContainer.Values - Class in org.infinispan.container
 
FIFODataContainer.Values() - Constructor for class org.infinispan.container.FIFODataContainer.Values
 
FIFOSimpleDataContainer - Class in org.infinispan.container
Based on the same techniques outlined in the SimpleDataContainer, this implementation always forces the collection of creation timestamps for entries.
FIFOSimpleDataContainer(int) - Constructor for class org.infinispan.container.FIFOSimpleDataContainer
 
FIFOSimpleDataContainer(int, int) - Constructor for class org.infinispan.container.FIFOSimpleDataContainer
 
FileCacheKey - Class in org.infinispan.lucene
Used as a key for file headers in a cache
FileCacheKey(String, String) - Constructor for class org.infinispan.lucene.FileCacheKey
 
FileCacheKey(String, String, boolean) - Constructor for class org.infinispan.lucene.FileCacheKey
 
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
 
fileExists(String) - Method in class org.infinispan.lucene.InfinispanDirectory
fileLength(String) - Method in class org.infinispan.lucene.InfinispanDirectory
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
 
FileMetadata - Class in org.infinispan.lucene
Header for Lucene files.
FileMetadata() - Constructor for class org.infinispan.lucene.FileMetadata
 
fileModified(String) - Method in class org.infinispan.lucene.InfinispanDirectory
FilesystemDirectory - Class in org.infinispan.demos.directory
 
FilesystemDirectory() - Constructor for class org.infinispan.demos.directory.FilesystemDirectory
 
fillInStackTrace() - Method in exception org.infinispan.marshall.NotSerializableException
 
findGetterForField(Class<?>, String) - Static method in class org.infinispan.util.ReflectionUtil
 
findNode(TreeNode, String, String) - Method in class org.infinispan.tools.doclet.config.XMLTreeOutputWalker
 
findSchemaInputStream() - Static method in class org.infinispan.config.InfinispanConfiguration
 
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.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.VersionAwareMarshaller
 
first - Variable in class org.infinispan.query.impl.AbstractIterator
 
first() - Method in class org.infinispan.query.impl.AbstractIterator
 
first() - Method in interface org.infinispan.query.QueryIterator
Jumps to the first result
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.lucene.InfinispanIndexIO.InfinispanIndexOutput
 
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
 
flushLockTimeout - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
forget(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
formatString(Object, Object...) - Static method in class org.infinispan.util.Util
 
FQN - Static variable in interface org.infinispan.marshall.Ids
 
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.Externalizer - Class in org.infinispan.tree
 
Fqn.Externalizer() - Constructor for class org.infinispan.tree.Fqn.Externalizer
 
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.
fromList(List) - 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.RemoteCommandsFactory
Creates an un-initialized command.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Writes contents of the stream to the store.
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.cloud.CloudCacheStore
 
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
 
fromStreamProcess(Object, PreparedStatement, ObjectInput) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
fromStreamSupport(ObjectInput) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
fromString(String) - Method in class org.infinispan.query.DefaultTransformer
 
fromString(String) - Method in interface org.infinispan.query.Transformer
 
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

generateContents() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
generateContents() - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
generateContents() - Method in class org.infinispan.tools.doclet.jmx.JmxHtmlGenerator
 
generateHtml(String) - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
generateHtml(String, String) - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
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) - Method in class org.infinispan.AbstractDelegatingCache
 
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) - 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() - 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(Object) - Method in class org.infinispan.util.concurrent.BufferedConcurrentHashMap
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.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
 
GET_KEY_VALUE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
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
 
getAffectedKeys() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.write.ClearCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.write.PutMapCommand
 
getAffectedKeys() - Method in interface org.infinispan.commands.write.WriteCommand
 
getAffectedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getAffectedKeys() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the set of keys that are affected by this transaction.
getAffectedNodes(Set<Object>) - Method in interface org.infinispan.distribution.DistributionManager
A helper method that retrieves a list of nodes affected by operations on a set of keys.
getAffectedNodes(Set<Object>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getAfter() - Method in class org.infinispan.config.CustomInterceptorConfig
 
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.
getAnnotatedFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
 
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
 
getAsyncListenerExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncListenerExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getAsyncStoreConfig() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getAsyncTransportExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncTransportExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getAtomicMap(Cache<?, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key.
getAtomicMap(NodeKey) - Method in class org.infinispan.tree.TreeStructureSupport
 
getAttribute(String) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributes() - Method in class org.infinispan.tools.schema.TreeNode
 
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.
getAvailability() - Method in class org.infinispan.jopr.CacheComponent
Return availability of this resource
getAvailability() - Method in class org.infinispan.jopr.CacheManagerComponent
Return availability of this resource.
getAverageReadTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAverageReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAverageWriteTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getBasicQuery(String, String) - Method in class org.infinispan.query.QueryFactory
This method is a basic query.
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.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
 
getBeanClass() - Method in class org.infinispan.tools.schema.TreeNode
 
getBefore() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getBinaryCacheStore() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.util.TypedProperties
 
getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyXid
 
getBucketName() - Method in class org.infinispan.loaders.bucket.Bucket
 
getBucketPrefix() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getBuf() - Method in class org.infinispan.io.ByteBuffer
 
getCache() - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
getCache() - Method in class org.infinispan.ec2demo.NucleotideCache
 
getCache() - Method in class org.infinispan.ec2demo.ProteinCache
 
getCache() - Method in class org.infinispan.lucene.InfinispanDirectory
 
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
 
getCacheDbNamePrefix() - 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 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 class org.infinispan.ec2demo.CacheBuilder
 
getCacheManager() - Static method in class org.infinispan.lucenedemo.DirectoryFactory
 
getCacheManager() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getCacheManager() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getCacheManagerStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheMode() - Method in class org.infinispan.config.Configuration
 
getCacheModeString() - Method in class org.infinispan.config.Configuration
 
getCacheName() - Method in class org.infinispan.CacheDelegate
Returns the cache name.
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
 
getCacheNames() - Method in interface org.infinispan.manager.CacheManager
If no named caches are registered, this method returns an empty set.
getCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCaches() - Method in interface org.infinispan.distribution.ConsistentHash
Should return a collection of cache addresses in the cluster.
getCaches() - Method in class org.infinispan.distribution.DefaultConsistentHash
 
getCaches() - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
getCaches() - Method in class org.infinispan.distribution.UnionConsistentHash
 
getCacheSize() - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
getCacheSize() - Method in class org.infinispan.ec2demo.NucleotideCache
 
getCacheSize() - Method in class org.infinispan.ec2demo.ProteinCache
 
getCacheStatus() - Method in class org.infinispan.CacheDelegate
Returns String representation of ComponentStatus enumeration in order to avoid class not found exceptions in JMX tools that don't have access to infinispan classes.
getCacheStore() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
getCacheStore() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
getCacheStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStore
 
getCacheStoreConfig() - Method in interface org.infinispan.loaders.CacheStore
Returns the configuration object associated to this cache store config.
getCacheStoreConfig() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
getCacheStoreConfig() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
getCacheStoreForRehashing() - Method in interface org.infinispan.distribution.DistributionManager
Retrieves a cache store if one is available and set up for use in rehashing.
getCacheStoreForRehashing() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getCatalogDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getChangeLogSize() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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 class org.infinispan.tools.schema.TreeNode
 
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
 
getClasses() - Method in class org.infinispan.query.backend.QueryHelper
Simple getter.
getClassForName(String) - Static method in class org.infinispan.jmx.ResourceDMBean
 
getClassMapping(String) - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getClassMappings() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getClassName() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getCloudService() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getCloudServiceLocation() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
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
 
getClusterSize() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getCoinToss() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
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
 
getCommandAwareRpcDispatcher() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCommandId() - Method in class org.infinispan.commands.control.LockControlCommand
 
getCommandId() - Method in class org.infinispan.commands.control.RehashControlCommand
 
getCommandId() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getCommandId() - Method in class org.infinispan.commands.read.EntrySetCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.read.KeySetCommand
 
getCommandId() - Method in class org.infinispan.commands.read.SizeCommand
 
getCommandId() - Method in class org.infinispan.commands.read.ValuesCommand
 
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
 
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.loaders.AbstractCacheStore
 
getConcurrencyLevel() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getConfigBeans() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
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.cloud.CloudCacheStore
 
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
 
getConfigurationClassName() - Method in class org.infinispan.util.ModuleProperties
 
getConfigurationNames() - Method in interface org.infinispan.config.ConfigurationRegistry
Gets the names of all registered configurations.
getConnection() - Method in class org.infinispan.jopr.CacheManagerComponent
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.ManagedConnectionFactory
 
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
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
 
getConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
Retrieves the consistent hash instance currently in use, which may be an instance of the configured ConsistentHash instance (which defaults to DefaultConsistentHash, or an instance of UnionConsistentHash if a rehash is in progress.
getConsistentHash() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getConsistentHashClass() - Method in class org.infinispan.config.Configuration
 
getContents() - Method in class org.infinispan.tree.NodeKey
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
getCountry() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
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
 
getCurrentNumberOfEntries() - Method in interface org.infinispan.stats.Stats
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.StatsImpl
 
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.CustomInterceptorsType
 
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
 
getDatasourceJndiLocation() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getDeadlockDetectionSpinDuration() - Method in class org.infinispan.config.Configuration
 
getDefaultConfiguration() - Method in interface org.infinispan.manager.CacheManager
Returns default configuration for this CacheManager
getDefaultConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
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
 
getDefaultThreadPrio(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultThreads(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
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
 
getDepth() - Method in class org.infinispan.tools.schema.TreeNode
 
getDetectedLocalDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getDetectedRemoteDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getDistance(Address, Address) - Method in interface org.infinispan.distribution.ConsistentHash
Calculates the logical distance between two addresses.
getDistance(Address, Address) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
getDistance(Address, Address) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
The distance between the first entries in the address array for two caches, a1 and a2.
getDistance(Address, Address) - Method in class org.infinispan.distribution.UnionConsistentHash
 
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
 
getDistributionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getDistributionManager() - Method in interface org.infinispan.AdvancedCache
Retrieves a reference to the DistributionManager if the cache is configured to use Distribution.
getDistributionManager() - Method in class org.infinispan.CacheDelegate
 
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.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
 
getEvictions() - Method in interface org.infinispan.stats.Stats
 
getEvictions() - Method in class org.infinispan.stats.StatsImpl
 
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
 
getExpiryDbPrefix() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getExpiryQueueSize() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
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.
getFieldName() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
 
getFields(Class<?>, Class<?>) - Static method in class org.infinispan.util.ReflectionUtil
 
getFileName() - Method in class org.infinispan.lucene.FileCacheKey
Get the fileName.
getFilePointer() - Method in class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexInput
 
getFilePointer() - Method in class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexOutput
 
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
 
getFlushLockTimeout() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
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
 
getFqn() - Method in class org.infinispan.tree.NodeKey
 
getFromConfiguration(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component from the Configuration
getFullLengthSequence() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getGanNucleoid() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
getGenbankAccessionNumber() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getGenomeSequenceNumber() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getGlobalComponentRegistry() - Method in class org.infinispan.factories.ComponentRegistry
 
getGlobalConfiguration() - Method in class org.infinispan.config.Configuration
 
getGlobalConfiguration() - Method in interface org.infinispan.manager.CacheManager
Returns global configuration for this CacheManager
getGlobalConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
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
 
getHits() - Method in interface org.infinispan.stats.Stats
 
getHits() - Method in class org.infinispan.stats.StatsImpl
 
getHoldCount() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
getHost() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getHostAge() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getHostGender() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
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
 
getIdentity() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getIndex() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getIndex(String) - Static method in class org.infinispan.lucenedemo.DirectoryFactory
 
getIndexName() - Method in interface org.infinispan.lucene.CacheKey
Get the name of the index to which this key is scoped to.
getIndexName() - Method in class org.infinispan.lucene.FileCacheKey
Get the indexName.
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
 
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
 
getInvalidHolders(Object, ConsistentHash, ConsistentHash) - Method in class org.infinispan.distribution.LeaveTask
 
getInvalidHolders(Object, ConsistentHash, ConsistentHash) - Method in class org.infinispan.distribution.RehashTask
 
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
 
getJGroupsChannel() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
getJmxDomain() - Method in class org.infinispan.config.GlobalConfiguration
 
getJmxDomain(String, MBeanServer) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
getKey() - Method in interface org.infinispan.commands.DataCommand
 
getKey() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getKey() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
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.control.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
Implements functionality defined by Map.get(Object) and Map.containsKey(Object) operations
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.
getLastModified() - Method in class org.infinispan.lucene.FileMetadata
 
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.TransientMortalCacheEntry
 
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
 
getLifecycleClassName() - Method in class org.infinispan.util.ModuleProperties
 
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
 
getList() - Method in class org.infinispan.loaders.modifications.Prepare
 
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
 
getLoadNonExpiredAllRowsSql() - 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
 
getLocallyInterruptedTransactions() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
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
 
getLockAcquisitionTimeout(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
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
 
getLockIntention() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Returns the key this transaction intends to lock.
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.distribution.JoinTask
 
getLog() - Method in class org.infinispan.distribution.LeaveTask
 
getLog() - Method in class org.infinispan.distribution.RehashTask
 
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
 
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.cloud.CloudCacheStoreConfig
 
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.TransientMortalCacheEntry
 
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(GlobalConfiguration) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
getMBeanServer() - Method in interface org.infinispan.jmx.MBeanServerLookup
 
getMBeanServer() - Method in class org.infinispan.jmx.PlatformMBeanServerLookup
 
getMBeanServerLookup() - Method in class org.infinispan.config.GlobalConfiguration
 
getMemberJoined(List<Address>, List<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMemberLeft(List<Address>, List<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
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.
getMembersJoined(List<Address>, List<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMembersLeft(List<Address>, List<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMisses() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getMisses() - Method in interface org.infinispan.stats.Stats
 
getMisses() - Method in class org.infinispan.stats.StatsImpl
 
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.config.Configuration
 
getName() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getName() - Method in class org.infinispan.manager.DefaultCacheManager
 
getName() - Method in class org.infinispan.tools.schema.TreeNode
 
getName() - Method in class org.infinispan.util.ModuleProperties
 
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.
getNewConsistentHash() - Method in class org.infinispan.distribution.UnionConsistentHash
 
getNewMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getNewMembers() - 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
 
getNonCacheComponents(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
getNonClusteredDefault() - Static method in class org.infinispan.config.GlobalConfiguration
Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
getNucleotideDetails(String) - Method in class org.infinispan.ec2demo.NucleotideCache
 
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
 
getOldConsistentHash() - Method in class org.infinispan.distribution.UnionConsistentHash
 
getOldMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getOldMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
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.
getOverlapWithNotDeadlockAwareLockOwners() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
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.LockControlCommand
 
getParameters() - Method in class org.infinispan.commands.control.RehashControlCommand
 
getParameters() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getParameters() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getParameters() - Method in class org.infinispan.commands.read.EntrySetCommand
 
getParameters() - Method in class org.infinispan.commands.read.KeySetCommand
 
getParameters() - Method in class org.infinispan.commands.read.SizeCommand
 
getParameters() - Method in class org.infinispan.commands.read.ValuesCommand
 
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.InvalidateL1Command
 
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.tools.schema.TreeNode
 
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.cloud.CloudCacheStoreConfig
 
getPassword() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getPassword() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getPendingPrepares() - Method in interface org.infinispan.distribution.TransactionLogger
Drains pending prepares.
getPendingPrepares() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getPhysicalAddresses() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's physical network addresses.
getPooledDataSource() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
getPosition() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getPrepares() - Method in class org.infinispan.interceptors.TxInterceptor
 
getProperties() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getProperties() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
getProperties() - Method in class org.infinispan.query.backend.QueryHelper
Simple getter.
getProperties() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProperty(String) - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getPropertyFromBeanConvention(Method) - Static method in class org.infinispan.tools.BeanConventions
 
getPropertyFromBeanConvention(Field) - Static method in class org.infinispan.tools.BeanConventions
 
getProtein_Data() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
getProteinDetails(String) - Method in class org.infinispan.ec2demo.ProteinCache
 
getProxy(Cache, Object, BatchContainer, InvocationContextContainer) - Method in class org.infinispan.atomic.AtomicHashMap
 
getProxyHost() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getProxyPort() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getPurgerThreads() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getPushStateTimeout() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
getQuery(Query) - Method in class org.infinispan.query.QueryFactory
This is a simple method that will just return a CacheQuery
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
getReflectionManager() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Returns an immutable set containing all the components that exists in the repository at this moment.
getRehashRpcTimeout() - Method in class org.infinispan.config.Configuration
 
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
 
getRemoveHits() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getRemoveHits() - Method in interface org.infinispan.stats.Stats
 
getRemoveHits() - Method in class org.infinispan.stats.StatsImpl
 
getRemoveMisses() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getRemoveMisses() - Method in interface org.infinispan.stats.Stats
 
getRemoveMisses() - Method in class org.infinispan.stats.StatsImpl
 
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.cloud.CloudCacheStoreConfig
 
getResources(String) - Static method in class org.infinispan.util.ModuleProperties
 
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
 
getResultSize() - Method in interface org.infinispan.query.CacheQuery
Gets the integer number of results.
getResultSize() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
getRetrievals() - Method in interface org.infinispan.stats.Stats
 
getRetrievals() - Method in class org.infinispan.stats.StatsImpl
 
getRollbacks() - Method in class org.infinispan.interceptors.TxInterceptor
 
getRoot() - Method in class org.infinispan.loaders.file.FileCacheStore
 
getRoot() - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
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
 
getRootDoc() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
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
 
getRunningCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
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
 
getSearchFactory() - Method in class org.infinispan.query.backend.QueryHelper
Simple getter.
getSelectExpiredRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getSelectRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getSequenceLength() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
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
 
getSingletonStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getSingletonStoreConfig() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getSize() - Method in class org.infinispan.lucene.FileMetadata
 
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
 
getStateRetrievalInitialRetryWaitTime() - Method in class org.infinispan.config.Configuration
 
getStateRetrievalNumRetries() - Method in class org.infinispan.config.Configuration
 
getStateRetrievalRetryWaitTimeIncreaseFactor() - Method in class org.infinispan.config.Configuration
 
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.InvalidationInterceptor
 
getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Returns whether an interceptor's statistics are being captured.
getStats() - Method in interface org.infinispan.AdvancedCache
 
getStats() - Method in class org.infinispan.CacheDelegate
 
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
 
getStores() - Method in interface org.infinispan.stats.Stats
 
getStores() - Method in class org.infinispan.stats.StatsImpl
 
getStream() - Method in class org.infinispan.io.ByteBuffer
 
getStreamBufferSize() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getStringBasedCacheStore() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
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(Object[]) - 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.
getSubType() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getSuccessRatio() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuccessRatioFloatingPoint() - 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.JdbcBinaryCacheStore
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getTableName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTableNamePrefix() - 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
 
getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
 
getTimeSinceStart() - Method in class org.infinispan.stats.StatsImpl
 
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.
getTotalNumberOfDetectedDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getTotalNumberOfEntries() - Method in interface org.infinispan.stats.Stats
 
getTotalNumberOfEntries() - Method in class org.infinispan.stats.StatsImpl
 
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
 
getTransactionIdentifier() - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Returns a JTA transaction.
getTransactionLogger() - Method in interface org.infinispan.distribution.DistributionManager
Retrieves the transaction logger instance associated with this DistributionManager
getTransactionLogger() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getTransactionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getTransactionManager() - Method in interface org.infinispan.AdvancedCache
 
getTransactionManager() - Method in class org.infinispan.CacheDelegate
 
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.
getTransactionManagerLookup() - Method in class org.infinispan.config.Configuration
 
getTransactionManagerLookupClass() - Method in class org.infinispan.config.Configuration
 
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
 
getTransportNodeName() - Method in class org.infinispan.config.GlobalConfiguration
 
getTransportProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getTx() - Method in class org.infinispan.loaders.modifications.Commit
 
getTx() - Method in class org.infinispan.loaders.modifications.Prepare
 
getType() - Method in class org.infinispan.loaders.modifications.Clear
 
getType() - Method in class org.infinispan.loaders.modifications.Commit
 
getType() - Method in interface org.infinispan.loaders.modifications.Modification
 
getType() - Method in class org.infinispan.loaders.modifications.Prepare
 
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
 
getType() - Method in class org.infinispan.tools.schema.TreeNode
 
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 interface org.infinispan.container.entries.CacheEntry
Retrieves the value of this entry
getValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
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.MortalCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Retrieves the value of the entry being modified.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Retrieves the value of the entry being deleted.
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.CacheComponent
Gather measurement data
getValues(MeasurementReport, Set<MeasurementScheduleRequest>) - Method in class org.infinispan.jopr.CacheManagerComponent
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
 
getViewId() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getViewId() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getViewId() - Method in interface org.infinispan.remoting.transport.Transport
 
getVirusDetails(String) - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
getVirusName() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getXaCacheAdapter(Transaction) - Method in class org.infinispan.transaction.xa.TransactionTable
 
getYearFound() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
GLOBAL_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheManagerJmxRegistration
 
GLOBAL_TRANSACTION - Static variable in interface org.infinispan.marshall.Ids
 
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.ExecutorFactoryType - Class in org.infinispan.config
 
GlobalConfiguration.ExecutorFactoryType(String) - Constructor for class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
 
GlobalConfiguration.ExecutorFactoryType() - Constructor for class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
 
GlobalConfiguration.FactoryClassWithPropertiesType - Class in org.infinispan.config
 
GlobalConfiguration.FactoryClassWithPropertiesType() - Constructor for class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
 
GlobalConfiguration.GlobalJmxStatisticsType - Class in org.infinispan.config
 
GlobalConfiguration.GlobalJmxStatisticsType() - Constructor for class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
GlobalConfiguration.ScheduledExecutorFactoryType - Class in org.infinispan.config
 
GlobalConfiguration.ScheduledExecutorFactoryType(String) - Constructor for class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
 
GlobalConfiguration.ScheduledExecutorFactoryType() - Constructor for class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
 
GlobalConfiguration.SerializationType - Class in org.infinispan.config
 
GlobalConfiguration.SerializationType() - Constructor for class org.infinispan.config.GlobalConfiguration.SerializationType
 
GlobalConfiguration.ShutdownHookBehavior - Enum in org.infinispan.config
Behavior of the JVM shutdown hook registered by the cache
GlobalConfiguration.ShutdownType - Class in org.infinispan.config
 
GlobalConfiguration.ShutdownType() - Constructor for class org.infinispan.config.GlobalConfiguration.ShutdownType
 
GlobalConfiguration.TransportType - Class in org.infinispan.config
 
GlobalConfiguration.TransportType() - Constructor for class org.infinispan.config.GlobalConfiguration.TransportType
 
GlobalConfiguration.TransportType(String) - Constructor for class org.infinispan.config.GlobalConfiguration.TransportType
 
GlobalTransaction - Class in org.infinispan.transaction.xa
Uniquely identifies a transaction that spans all JVMs in a cluster.
GlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
 
GlobalTransaction.Externalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
GlobalTransactionFactory - Class in org.infinispan.transaction.xa
Factory for GlobalTransaction/DadlockDetectingGlobalTransaction.
GlobalTransactionFactory() - Constructor for class org.infinispan.transaction.xa.GlobalTransactionFactory
 
GlobalTransactionFactory(boolean) - Constructor for class org.infinispan.transaction.xa.GlobalTransactionFactory
 
globalTx - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
gtxFactory - Variable in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 

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(String) - Method in class org.infinispan.tools.schema.TreeNode
 
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
 
hasChildren() - Method in class org.infinispan.tools.schema.TreeNode
 
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.Configuration.QueryConfigurationBean
 
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 - Variable in class org.infinispan.config.Configuration.ClusteringType
 
hash - Variable in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
hash(Object) - Static method in class org.infinispan.util.AbstractMap
 
hashCode() - Method in class org.infinispan.commands.control.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.InvalidateCommand
 
hashCode() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
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.AsyncType
 
hashCode() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
 
hashCode() - Method in class org.infinispan.config.Configuration.ClusteringType
 
hashCode() - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
 
hashCode() - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
 
hashCode() - Method in class org.infinispan.config.Configuration.EvictionType
 
hashCode() - Method in class org.infinispan.config.Configuration.ExpirationType
 
hashCode() - Method in class org.infinispan.config.Configuration
 
hashCode() - Method in class org.infinispan.config.Configuration.HashType
 
hashCode() - Method in class org.infinispan.config.Configuration.L1Type
 
hashCode() - Method in class org.infinispan.config.Configuration.LockingType
 
hashCode() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
hashCode() - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
hashCode() - Method in class org.infinispan.config.Configuration.SyncType
 
hashCode() - Method in class org.infinispan.config.Configuration.TransactionType
 
hashCode() - Method in class org.infinispan.config.Configuration.UnsafeType
 
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.container.entries.ImmortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.MortalCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.TransientCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
hashCode() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
hashCode() - Method in class org.infinispan.distribution.DefaultConsistentHash
 
hashCode() - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
hashCode() - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
hashCode() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
hashCode() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
hashCode() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
hashCode() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
hashCode() - Method in class org.infinispan.loaders.modifications.Commit
 
hashCode() - Method in class org.infinispan.loaders.modifications.Prepare
 
hashCode() - Method in class org.infinispan.loaders.modifications.Remove
 
hashCode() - Method in class org.infinispan.loaders.modifications.Store
 
hashCode() - Method in class org.infinispan.lucene.FileCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileMetadata
 
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.tools.doclet.jmx.JmxComponent
 
hashCode() - Method in class org.infinispan.tools.schema.TreeNode
 
hashCode() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
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
 
hasLockedKey(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
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.interceptors.base.CommandInterceptor
 
hasNext() - Method in class org.infinispan.query.impl.AbstractIterator
 
hasPendingPrepare(PrepareCommand) - Method in class org.infinispan.transaction.TransactionLog
 
hasPrevious() - Method in class org.infinispan.query.impl.AbstractIterator
 
hookBehavior - Variable in class org.infinispan.config.GlobalConfiguration.ShutdownType
 
HtmlGenerator - Class in org.infinispan.tools.doclet.html
Generates HTML documents
HtmlGenerator(String, String, String, String, String, String, List<String>) - Constructor for class org.infinispan.tools.doclet.html.HtmlGenerator
 

I

icc - Variable in class org.infinispan.CacheDelegate
 
icc - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
icc - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
icc - Variable in class org.infinispan.tree.TreeStructureSupport
 
identityConstraint(XSIdentityConstraint) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
Ids - Interface in org.infinispan.marshall
Indexes.
ignoreModifications - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
immediateLockForWriting(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Same as LockSupportCacheStore.lockForWriting(String), but with 0 timeout.
IMMORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
IMMORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
ImmortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is immortal/cannot expire
ImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
ImmortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
ImmortalCacheValue - Class in org.infinispan.container.entries
An immortal cache value, to correspond with ImmortalCacheEntry
ImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
ImmortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
IMMUTABLE_MAP - Static variable in interface org.infinispan.marshall.Ids
 
immutableCollectionCopy(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Creates a new immutable copy of the specified Collection.
immutableCollectionWrap(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Wraps a collection with an immutable collection.
immutableEntry(Map.Entry<K, V>) - Static method in class org.infinispan.util.Immutables
Wraps a Map.Entry} with an immutable Map.Entry}.
immutableInternalCacheEntry(InternalCacheEntry) - Static method in class org.infinispan.util.Immutables
Wraps a InternalCacheEntry} with an immutable InternalCacheEntry}.
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.
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

For more details refer to: https://jira.jboss.org/jira/browse/ISPN-70 https://jira.jboss.org/jira/browse/ISPN-48

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.
inboundInvocationHandler - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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
 
index - Variable in class org.infinispan.config.CustomInterceptorConfig
 
index - Variable in class org.infinispan.query.impl.AbstractIterator
 
indexLocalOnly - Variable in class org.infinispan.config.Configuration.QueryConfigurationBean
 
indexOf(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
IndexSearcherCloser - Class in org.infinispan.query.backend
Class with static method that is called by CacheQueryImpl and EagerIterator

Simply an abstraction for one method to reduce unnecessary code replication.

IndexSearcherCloser() - Constructor for class org.infinispan.query.backend.IndexSearcherCloser
 
infinispanClasses() - Static method in class org.infinispan.util.ClassFinder
 
infinispanClasses(String) - Static method in class org.infinispan.util.ClassFinder
 
InfinispanCollections - Class in org.infinispan.util
Static helpers for Infinispan-specific collections
InfinispanCollections() - Constructor for class org.infinispan.util.InfinispanCollections
 
InfinispanConfiguration - Class in org.infinispan.config
InfinispanConfiguration encapsulates root component of Infinispan XML configuration

Note that class InfinispanConfiguration contains JAXB annotations.

InfinispanConfiguration() - Constructor for class org.infinispan.config.InfinispanConfiguration
Should never called.
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
 
InfinispanDirectory - Class in org.infinispan.lucene
Implementation that uses Infinispan to store Lucene indices.
InfinispanDirectory(Cache<CacheKey, Object>, String, LockFactory, int) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<CacheKey, Object>, String, LockFactory) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<CacheKey, Object>, String, int) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<CacheKey, Object>, String) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<CacheKey, Object>) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanFluDemo - Class in org.infinispan.ec2demo
 
InfinispanFluDemo() - Constructor for class org.infinispan.ec2demo.InfinispanFluDemo
 
InfinispanIndexIO - Class in org.infinispan.lucene
Deal with input-output operations on Infinispan based Directory
InfinispanIndexIO() - Constructor for class org.infinispan.lucene.InfinispanIndexIO
 
InfinispanIndexIO.InfinispanIndexInput - Class in org.infinispan.lucene
Responsible for writing into Directory
InfinispanIndexIO.InfinispanIndexInput(Cache<CacheKey, Object>, FileCacheKey) - Constructor for class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexInput
 
InfinispanIndexIO.InfinispanIndexInput(Cache<CacheKey, Object>, FileCacheKey, int) - Constructor for class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexInput
 
InfinispanIndexIO.InfinispanIndexOutput - Class in org.infinispan.lucene
Responsible for reading from Directory
InfinispanIndexIO.InfinispanIndexOutput(Cache<CacheKey, Object>, FileCacheKey, int, FileMetadata) - Constructor for class org.infinispan.lucene.InfinispanIndexIO.InfinispanIndexOutput
 
Influenza_N_P_CR_Element - Class in org.infinispan.ec2demo
 
Influenza_N_P_CR_Element() - Constructor for class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
Influenza_Parser - Class in org.infinispan.ec2demo
 
Influenza_Parser() - Constructor for class org.infinispan.ec2demo.Influenza_Parser
 
InfluenzaDataLoader - Class in org.infinispan.ec2demo
 
InfluenzaDataLoader() - Constructor for class org.infinispan.ec2demo.InfluenzaDataLoader
 
InfluenzaVirusCache - Class in org.infinispan.ec2demo
 
InfluenzaVirusCache(CacheBuilder) - Constructor for class org.infinispan.ec2demo.InfluenzaVirusCache
 
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
 
informRehashOnJoin(Address, boolean) - Method in interface org.infinispan.distribution.DistributionManager
This will cause all nodes to add the joiner to their consistent hash instance (usually by creating a UnionConsistentHash
informRehashOnJoin(Address, boolean) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
init(DistributionManager, Configuration, DataContainer, CommandsFactory) - Method in class org.infinispan.commands.control.RehashControlCommand
 
init(Transport) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
init(InterceptorChain, InvocationContextContainer) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
init(InterceptorChain, InvocationContextContainer, TransactionTable) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.ClearCommand
 
init(Configuration, DistributionManager, CacheNotifier, DataContainer) - 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() - Method in class org.infinispan.container.EntryFactoryImpl
 
init(TransactionManager, TransactionTable) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
init(Configuration, RpcManager, CacheManagerNotifier, CommandsFactory, DataContainer, InterceptorChain, InvocationContextContainer, CacheLoaderManager) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
init(ServletConfig) - Method in class org.infinispan.ec2demo.web.CacheSearchServlet
 
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(TransactionTable, LockManager, TransactionManager, DistributionManager) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
init(CommandsFactory) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
init(TransactionManager, TransactionTable, TransactionLog, Configuration) - 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.
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.cloud.CloudCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, Marshaller, BlobStoreContext, BlobStore, AsyncBlobStore, boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
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.AsyncStore
 
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(byte[], int) - Method in class org.infinispan.marshall.MarshalledValue
 
init(SearchFactoryImplementor, TransactionManager) - Method in class org.infinispan.query.backend.LocalQueryInterceptor
 
init(SearchFactoryImplementor, TransactionManager) - Method in class org.infinispan.query.backend.QueryInterceptor
 
init(Configuration) - Method in class org.infinispan.transaction.xa.GlobalTransactionFactory
 
init() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
initChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
initForWriting() - Method in class org.infinispan.atomic.AtomicHashMap
Initializes the delta instance to start recording changes.
initialize(DataContainer, InvocationContextContainer, CommandsFactory, InterceptorChain) - 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(ScheduledExecutorService, Configuration, Cache<Object, Object>, DataContainer, CacheLoaderManager) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
initialize(AdvancedCache, GlobalConfiguration) - 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, GlobalTransactionFactory, CacheManager) - 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
 
initialRetryWaitTime - Variable in class org.infinispan.config.Configuration.StateRetrievalType
 
initLinks() - Method in class org.infinispan.container.FIFODataContainer
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
 
inject(Transport) - Method in class org.infinispan.commands.RemoteCommandsFactory
 
inject(ComponentRegistry) - Method in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
inject(ComponentRegistry) - Method in class org.infinispan.config.Configuration
 
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(DistributionManager, Transport) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
inject(Cache, Marshaller, Configuration) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
inject(RemoteCommandsFactory) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
inject(Marshaller) - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
inject(ClassLoader, RemoteCommandsFactory) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
inject(GlobalComponentRegistry) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
inject(DistributionManager) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
injectCacheManager(CacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
injectDependencies(EvictionManager, InvocationContextContainer, CommandsFactory, InterceptorChain, Configuration, CacheNotifier, ComponentRegistry, TransactionManager, BatchContainer, RpcManager, DataContainer, Marshaller, ResponseGenerator, DistributionManager, CacheManager, StateTransferManager) - Method in class org.infinispan.CacheDelegate
 
injectDependencies(DataContainer, LockManager, Configuration, CacheNotifier) - Method in class org.infinispan.container.EntryFactoryImpl
 
injectDependencies() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Injects dependencies into this component.
injectDependencies(CacheLoaderManager, DataContainer, EntryFactory, CacheNotifier) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
injectDependencies(DistributionManager, CommandsFactory, DataContainer, EntryFactory) - 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
 
injectMarshaller(Marshaller) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Inserts a new Bucket in the storage system.
insertBucket(Bucket) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.file.FileCacheStore
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
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.remoting.responses.UnsureResponse
 
INSTANCE - Static variable in class org.infinispan.tree.FqnComparator
 
instantiateGlobalTransaction() - Method in class org.infinispan.transaction.xa.GlobalTransactionFactory
 
interceptor - Variable in class org.infinispan.config.CustomInterceptorConfig
 
interceptorChain - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
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(boolean, boolean) - Constructor for class org.infinispan.container.entries.InternalEntryFactory
 
interruptProcessingThread() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Tries to interrupt the processing thread.
invalidate(InvocationContext, Object) - Method in class org.infinispan.commands.write.InvalidateCommand
 
INVALIDATE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
INVALIDATE_L1_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
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
 
invalidateInvalidHolders(ConsistentHash, ConsistentHash) - Method in class org.infinispan.distribution.RehashTask
 
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(boolean, DataContainer, Configuration, 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.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, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
invokeRemotely(Collection<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(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(Collection<Address>, ReplicableCommand, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to a specified set of recipients
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to a specified set of recipients
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeRemotely(Collection<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(Collection<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture) except that you can specify a timeout.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long) - 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
 
isAdjacent(Address, Address) - Method in interface org.infinispan.distribution.ConsistentHash
Tests whether two addresses are logically next to each other in the hash space.
isAdjacent(Address, Address) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
isAdjacent(Address, Address) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
Two hashes are adjacent if they are next to each other in the consistent hash.
isAdjacent(Address, Address) - Method in class org.infinispan.distribution.UnionConsistentHash
 
isAffectedByRehash(Object) - Method in interface org.infinispan.distribution.DistributionManager
Tests whether a given key is affected by a rehash that may be in progress.
isAffectedByRehash(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
isAfterFirst() - Method in class org.infinispan.query.impl.AbstractIterator
 
isAfterFirst() - Method in interface org.infinispan.query.QueryIterator
 
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.
isAssignableFrom(List<Class<?>>, Class<?>) - Static method in class org.infinispan.util.ClassFinder
 
isAssignableFrom(Class<?>) - Static method in class org.infinispan.util.ClassFinder
 
isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isBeforeLast() - Method in class org.infinispan.query.impl.AbstractIterator
 
isBeforeLast() - Method in interface org.infinispan.query.QueryIterator
 
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.BufferedConcurrentHashMap
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.EntrySet
 
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 class org.infinispan.config.Configuration.QueryConfigurationBean
 
isEnabled() - Method in interface org.infinispan.distribution.TransactionLogger
Checks whether transaction logging is enabled
isEnabled() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
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
 
isEnableDeadlockDetection() - Method in class org.infinispan.config.Configuration
 
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.control.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 - Variable in class org.infinispan.config.CustomInterceptorConfig
 
isFirst() - Method in class org.infinispan.config.CustomInterceptorConfig
 
isFirst() - Method in class org.infinispan.query.impl.AbstractIterator
 
isFirst() - Method in interface org.infinispan.query.QueryIterator
 
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.control.LockControlCommand
 
isIndexingEnabled() - Method in class org.infinispan.config.Configuration
 
isIndexLocalOnly() - Method in class org.infinispan.config.Configuration
 
isIndexLocalOnly() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
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
 
isJoinComplete() - Method in interface org.infinispan.distribution.DistributionManager
Tests whether the current instance has completed joining the cluster
isJoinComplete() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
isKeyLocalToAddress(Address, Object, int) - Method in class org.infinispan.distribution.AbstractConsistentHash
 
isKeyLocalToAddress(Address, Object, int) - Method in interface org.infinispan.distribution.ConsistentHash
Test to see whether a key is mapped to a given address.
isKeyLocalToAddress(Address, Object, int) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
isL1CacheEnabled() - Method in class org.infinispan.config.Configuration
 
isL1OnRehash() - Method in class org.infinispan.config.Configuration
 
isLast - Variable in class org.infinispan.config.CustomInterceptorConfig
 
isLast() - Method in class org.infinispan.config.CustomInterceptorConfig
 
isLast() - Method in class org.infinispan.query.impl.AbstractIterator
 
isLast() - Method in interface org.infinispan.query.QueryIterator
 
isLazyPurgingOnly() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
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
 
isLocatedLocally(String) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
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
 
isLockKey() - Method in class org.infinispan.lucene.FileCacheKey
Get the isLockKey.
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.
isMarkedForRollback() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Once marked for rollback, the call to DeadlockDetectingGlobalTransaction.interruptProcessingThread() will be ignored.
isNonExistent() - Method in class org.infinispan.commands.write.RemoveCommand
 
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 - Variable in class org.infinispan.config.Configuration.LockingType
 
IsolationLevel - Enum in org.infinispan.util.concurrent
Various transaction isolation levels as an enumerated class.
isOnePhase() - Method in class org.infinispan.loaders.modifications.Prepare
 
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
 
isRehashEnabled() - Method in class org.infinispan.config.Configuration
 
isRehashInProgress() - Method in interface org.infinispan.distribution.DistributionManager
Tests whether a rehash is in progress
isRehashInProgress() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
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
 
isReplicatingTo(Address) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Is this global transaction replicating to the given address?
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.cloud.CloudCacheStoreConfig
 
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.interceptors.TxInterceptor
 
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
 
isSuccessful() - Method in class org.infinispan.remoting.responses.UnsureResponse
 
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() - Method in class org.infinispan.config.Configuration.ClusteringType
 
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
 
isTransactionInProgress() - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Returns a boolean value whether or not a transaction is in progress (JTA transaction and in this case *not* an org.hibernate transaction).
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(String) - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
isValid() - Method in interface org.infinispan.tree.Node
Tests if a node reference is still valid.
isValid() - Method in class org.infinispan.tree.NodeImpl
 
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.EntrySet
 
iterator() - Method in class org.infinispan.container.FIFODataContainer
 
iterator() - Method in class org.infinispan.container.