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
 
AbstractConfigHtmlGenerator - Class in org.infinispan.tools.doclet.config
 
AbstractConfigHtmlGenerator(String, String, String, String, String, String, List<String>) - Constructor for class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
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
 
AbstractInProcessFuture<V> - Class in org.infinispan.util.concurrent
An abstract Future that has "completed"
AbstractInProcessFuture() - Constructor for class org.infinispan.util.concurrent.AbstractInProcessFuture
 
AbstractInProcessNotifyingFuture<V> - Class in org.infinispan.util.concurrent
An abstract NotifyingFuture that has "completed"
AbstractInProcessNotifyingFuture() - Constructor for class org.infinispan.util.concurrent.AbstractInProcessNotifyingFuture
 
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
 
AbstractJdbcCacheStoreConfig - Class in org.infinispan.loaders.jdbc
This is an abstract configuration class containing common elements for all JDBC cache store types.
AbstractJdbcCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
AbstractJmxRegistration - Class in org.infinispan.jmx
Parent class for top level JMX component registration.
AbstractJmxRegistration() - Constructor for class org.infinispan.jmx.AbstractJmxRegistration
 
AbstractKeyOperation - Class in org.infinispan.client.hotrod.impl.operations
Basic class for all hot rod operations that manipulate a key.
AbstractKeyOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
AbstractKeyValueOperation - Class in org.infinispan.client.hotrod.impl.operations
Base class for all operations that manipulate a key and a value.
AbstractKeyValueOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
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
 
AbstractLocalCommand - Class in org.infinispan.commands.read
Abstract class
AbstractLocalCommand() - Constructor for class org.infinispan.commands.read.AbstractLocalCommand
 
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 implementation containing shared implementations.
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
 
AbstractNonDelegatingJdbcCacheStoreConfig - Class in org.infinispan.loaders.jdbc
An abstract configuration for JDBC cache stores which have support for locking.
AbstractNonDelegatingJdbcCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
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
 
AbstractStreamingMarshaller - Class in org.infinispan.marshall
Abstract marshaller
AbstractStreamingMarshaller() - Constructor for class org.infinispan.marshall.AbstractStreamingMarshaller
 
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
 
AbstractTransport - Class in org.infinispan.client.hotrod.impl.transport
Support class for transport implementations.
AbstractTransport(TransportFactory) - Constructor for class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
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
 
activateObject(Object, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
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(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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
 
addAll(Collection<? extends Object>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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
 
addChannel(CacheListener.ChannelNotifyParams) - Method in class org.infinispan.server.websocket.CacheListener
 
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.client.hotrod.impl.RemoteCacheSupport
 
addListener(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
Operation might be supported for smart clients that will be able to register for topology changes.
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
 
addStats(String, String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
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
 
alwaysProvideInMemoryState - Variable in class org.infinispan.config.Configuration.StateRetrievalType
 
annotation(XSAnnotation) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
appendIntereceptor(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Appends at the end.
applyClear() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
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.
aquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
Acquires a readlock on all chunks for this file, to make sure chunks are not deleted while iterating on the group.
aquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Acquires a readlock, in order to prevent other invocations to SegmentReadLocker.deleteOrReleaseReadLock(String) from deleting the file.
aquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
doesn't do anything and returns true
aquireReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
Acquires a readlock, in order to prevent other invocations to SegmentReadLocker.deleteOrReleaseReadLock(String) from deleting the file.
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_EXECUTOR_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
The default implementation of AtomicMap.
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 consistency and isolation for concurrent readers while writes may also be going on.
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 or safely constructs and registers atomic maps with a given cache.
AtomicMapLookup() - Constructor for class org.infinispan.atomic.AtomicMapLookup
 
attachGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.control.LockControlCommand
 
attachListener(FutureListener) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
attachListener(FutureListener<V>) - Method in class org.infinispan.util.concurrent.AbstractInProcessNotifyingFuture
 
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.GridInputStream
 
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

BaseLockFactory - Class in org.infinispan.lucene.locking
Default factory for locks obtained in InfinispanDirectory, this factory produces instances of BaseLuceneLock.
BaseLockFactory(Cache, String) - Constructor for class org.infinispan.lucene.locking.BaseLockFactory
 
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(Principal) - Method in class org.infinispan.demos.gridfs.GridStore
 
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
BinaryVersionedValue - Class in org.infinispan.client.hotrod.impl
 
BinaryVersionedValue(long, byte[]) - Constructor for class org.infinispan.client.hotrod.impl.BinaryVersionedValue
 
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
 
BoundedConcurrentHashMap<K,V> - Class in org.infinispan.util.concurrent
A hash table supporting full concurrency of retrievals and adjustable expected concurrency for updates.
BoundedConcurrentHashMap(int, int, BoundedConcurrentHashMap.Eviction, BoundedConcurrentHashMap.EvictionListener<K, V>) - Constructor for class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, load factor and concurrency level.
BoundedConcurrentHashMap(int, int) - Constructor for class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, load factor, concurrency level and LRU eviction policy.
BoundedConcurrentHashMap(int, int, BoundedConcurrentHashMap.Eviction) - Constructor for class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, load factor, concurrency level and eviction strategy.
BoundedConcurrentHashMap(int) - Constructor for class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, default concurrency level and LRU eviction policy.
BoundedConcurrentHashMap() - Constructor for class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Creates a new, empty map with the default maximum capacity
BoundedConcurrentHashMap.Eviction - Enum in org.infinispan.util.concurrent
 
BoundedConcurrentHashMap.EvictionListener<K,V> - Interface in org.infinispan.util.concurrent
 
BoundedConcurrentHashMap.EvictionPolicy<K,V> - Interface in org.infinispan.util.concurrent
 
boundedDataContainer(int, int, EvictionStrategy, EvictionThreadPolicy) - Static method in class org.infinispan.container.DefaultDataContainer
 
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
 
BucketBasedCacheStore.BucketHandler - Interface in org.infinispan.loaders.bucket
 
BucketBasedCacheStore.CollectionGeneratingBucketHandler<T> - Class in org.infinispan.loaders.bucket
 
BucketBasedCacheStore.CollectionGeneratingBucketHandler() - Constructor for class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
buffer - Variable in class org.infinispan.query.impl.AbstractIterator
 
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, ConsistentHash, List<Address>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
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, ConsistentHash, List<Address>) - 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
 
BULK_GET_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
BULK_GET_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
BulkGetOperation - Class in org.infinispan.client.hotrod.impl.operations
Reads more keys at a time.
BulkGetOperation(TransportFactory, byte[], AtomicInteger, Flag[], int) - Constructor for class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
BYTE_ARRAY_KEY - Static variable in interface org.infinispan.marshall.Ids
 
ByteArrayKey - Class in org.infinispan.util
Wrapper class for byte[] keys.
ByteArrayKey(byte[]) - Constructor for class org.infinispan.util.ByteArrayKey
 
ByteArrayKey.Externalizer - Class in org.infinispan.util
 
ByteArrayKey.Externalizer() - Constructor for class org.infinispan.util.ByteArrayKey.Externalizer
 
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.AbstractCacheLoader
 
cache - Variable in class org.infinispan.query.impl.AbstractIterator
 
cache - Variable in class org.infinispan.tree.TreeStructureSupport
 
CACHE_NAME - Static variable in interface org.infinispan.server.websocket.OpHandler
 
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
 
cacheContainer - Static variable in class org.infinispan.demos.gridfs.CacheManagerHolder
 
CacheContainer - Interface in org.infinispan.manager
A CacheContainer is the primary mechanism for retrieving a Cache instance, and is often used as a starting point to using the Cache.
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.
cacheEntryCreated(CacheEntryCreatedEvent) - Method in class org.infinispan.server.websocket.CacheListener
 
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.
cacheEntryModified(CacheEntryModifiedEvent) - Method in class org.infinispan.server.websocket.CacheListener
 
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.
cacheEntryRemoved(CacheEntryRemovedEvent) - Method in class org.infinispan.server.websocket.CacheListener
 
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
 
CacheListener - Class in org.infinispan.server.websocket
Cache listener.
CacheListener() - Constructor for class org.infinispan.server.websocket.CacheListener
 
CacheListener.ChannelNotifyParams - Class in org.infinispan.server.websocket
 
CacheListener.ChannelNotifyParams(Channel, String, String[]) - Constructor for class org.infinispan.server.websocket.CacheListener.ChannelNotifyParams
 
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
 
CacheLoaderMetadata - Annotation Type in org.infinispan.loaders
Allows you to provide metadata, such as CacheLoaderConfig type via annotation so that the CacheLoader or CacheStore need not be instantiated by the configuration parser to set up the cache loader configuration.
CacheManager - Interface in org.infinispan.manager
Deprecated. 
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
 
CacheManagerHolder - Class in org.infinispan.demos.gridfs
A bootstrapping startup listener which creates and holds a cache instance
CacheManagerHolder() - Constructor for class org.infinispan.demos.gridfs.CacheManagerHolder
 
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.client.hotrod.impl.operations.HotRodOperation
 
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
 
CacheSupport<K,V> - Class in org.infinispan
 
CacheSupport() - Constructor for class org.infinispan.CacheSupport
 
CacheSupport(long, long) - Constructor for class org.infinispan.CacheSupport
 
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.client.hotrod.impl.async.NotifyingFutureImpl
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
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
 
ChannelUtils - Class in org.infinispan.server.websocket
Channel Utilities.
ChannelUtils() - Constructor for class org.infinispan.server.websocket.ChannelUtils
 
checkAuthentication(ITransaction) - Method in class org.infinispan.demos.gridfs.GridStore
 
checkEagerLockingAndDld(Configuration, boolean) - Static method in class org.infinispan.config.ConfigurationValidatingVisitor
 
checkForErrorsInResponseStatus(short, long, Transport) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
checkParentDirs(String, boolean) - Method in class org.infinispan.io.GridFile
Checks whether the parent directories are present (and are directories).
checkStatisticsUsed() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
ChunkCacheKey - Class in org.infinispan.lucene
Used as a key to distinguish file chunk in cache.
ChunkCacheKey(String, String, int) - Constructor for class org.infinispan.lucene.ChunkCacheKey
 
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(Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
clear() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clear() - Method in interface org.infinispan.container.DataContainer
Removes all entries in the container
clear() - Method in class org.infinispan.container.DefaultDataContainer
 
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.loaders.remote.RemoteCacheStore
 
clear() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Removes all of the mappings from this map.
clear() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.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.ReadOnlyDataContainerBackedKeySet
 
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
 
CLEAR_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CLEAR_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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
 
clearAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
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.BaseLockFactory
clearLock(String) - Method in class org.infinispan.lucene.locking.TransactionalLockFactory
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 - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to clear operation as defined by Hot Rod protocol specification.
ClearOperation(TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
ClearOperation.Externalizer - Class in org.infinispan.atomic
 
ClearOperation.Externalizer() - Constructor for class org.infinispan.atomic.ClearOperation.Externalizer
 
CLIENT_INTELLIGENCE_BASIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CLIENT_INTELLIGENCE_HASH_DISTRIBUTION_AWARE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CLIENT_INTELLIGENCE_TOPOLOGY_AWARE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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.AbstractJdbcCacheStoreConfig
 
clone() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
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.lucene.InfinispanIndexInput
 
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.GridInputStream
 
close() - Method in class org.infinispan.io.GridOutputStream
 
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.InfinispanIndexInput
 
close() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
close() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
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
 
close(Closeable) - Static method in class org.infinispan.util.Util
 
closeConnection() - Method in class org.infinispan.jopr.ConnectionHelper
If necessary attempt to close the EMS connection, then set this.connection null.
closeSearcher(Searcher, ReaderProvider) - Static method in class org.infinispan.query.backend.IndexSearcherCloser
 
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
 
COMMAND_TIMEOUT_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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(ITransaction) - Method in class org.infinispan.demos.gridfs.GridStore
 
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() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
compact() - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
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
 
CONFIG_REF - Static variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
CONFIG_REF_DESC_ATT - Static variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
CONFIG_REF_NAME_ATT - Static variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
CONFIG_REF_PARENT_NAME_ATT - Static variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
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.marshall.jboss.GenericJBossMarshaller
 
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
 
ConfigurationProperties - Class in org.infinispan.client.hotrod.impl
Encapsulate all config properties here
ConfigurationProperties() - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationProperties(String) - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationProperties(Properties) - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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 - Variable in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
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
 
consider(Collection<? extends InternalCacheEntry>) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
ConsistentHash - Interface in org.infinispan.client.hotrod.impl.consistenthash
Abstraction for the used consistent hash.
ConsistentHash - Interface in org.infinispan.distribution
A consistent hash algorithm implementation.
consistentHashClass - Variable in class org.infinispan.config.Configuration.HashType
 
ConsistentHashFactory - Class in org.infinispan.client.hotrod.impl.consistenthash
Factory for ConsistentHash function.
ConsistentHashFactory() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
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
 
ConsistentHashV1 - Class in org.infinispan.client.hotrod.impl.consistenthash
Version one consistent hash function based on MurmurHash2;
ConsistentHashV1() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
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.BoundedConcurrentHashMap
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.ReadOnlyDataContainerBackedKeySet
 
contains(Object) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns true if this set contains the specified element.
CONTAINS_KEY_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CONTAINS_KEY_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
containsAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
containsAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
containsKey(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
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.DefaultDataContainer
 
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.loaders.remote.RemoteCacheStore
 
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.BoundedConcurrentHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
ContainsKeyOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "containsKey" operation as described in Hot Rod protocol specification.
ContainsKeyOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.ContainsKeyOperation
 
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.client.hotrod.impl.RemoteCacheSupport
 
containsValue(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
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.BoundedConcurrentHashMap
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
 
counter - Static variable in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
cr - Variable in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
create(Object, Object) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
create(Object, Object, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
create(Object, Object, long, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
create(Object, Object, long, long, long, long) - Static method in class org.infinispan.container.entries.InternalEntryFactory
 
createAndWire(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
 
createCache(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.
createFolder(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
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
 
createNewFile() - Method in class org.infinispan.io.GridFile
 
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
 
createResource(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
createStoredClassCatalog(Database) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
 
createStoredMapViewOfDatabase(Database, StoredClassCatalog, StreamingMarshaller) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
create a StoredMap persisted by the database
createStoredSortedMapForKeyExpiry(Database, StoredClassCatalog, StreamingMarshaller) - 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
 
CURRENT_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of entries currently in the Hot Rod server
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.io.GridFilesystem
 
data - Variable in class org.infinispan.remoting.MIMECacheEntry
The payload.
DatabaseType - Enum in org.infinispan.loaders.jdbc
Supported database dialects for the JDBC cache stores
databaseType - Variable in class org.infinispan.loaders.jdbc.TableManipulation
 
dataCacheName - Static variable in class org.infinispan.demos.gridfs.CacheManagerHolder
 
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, StreamingMarshaller) - 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_BUF_SIZE - Static variable in class org.infinispan.marshall.AbstractMarshaller
 
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.lucene.InfinispanDirectory
Used as default chunk size, can be overriden at construction time.
DEFAULT_CACHE_NAME - Static variable in interface org.infinispan.manager.CacheContainer
 
DEFAULT_CACHE_NAME_BYTES - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
default_chunk_size - Variable in class org.infinispan.io.GridFilesystem
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
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_EXECUTOR_FACTORY_POOL_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_EXECUTOR_FACTORY_QUEUE_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
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().
DEFAULT_MARSHALLER_FACTORY - Static variable in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
DefaultAsyncExecutorFactory - Class in org.infinispan.client.hotrod.impl.async
Default implementation for ExecutorFactory based on an ThreadPoolExecutor.
DefaultAsyncExecutorFactory() - Constructor for class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
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.
defaultCl - Variable in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
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
 
DefaultDataContainer - Class in org.infinispan.container
Simple data container that does not order entries for eviction, implemented using two ConcurrentHashMaps, one for mortal and one for immortal entries.
DefaultDataContainer(int) - Constructor for class org.infinispan.container.DefaultDataContainer
 
DefaultDataContainer(int, int, EvictionStrategy, EvictionThreadPolicy) - Constructor for class org.infinispan.container.DefaultDataContainer
 
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
Deprecated. since 4.1 when DefaultTwoWayKey2StringMapper which is a replacement this implementation.
DefaultKey2StringMapper() - Constructor for class org.infinispan.loaders.jdbc.stringbased.DefaultKey2StringMapper
Deprecated.  
defaultLifespan - Variable in class org.infinispan.CacheSupport
 
defaultMaxIdleTime - Variable in class org.infinispan.CacheSupport
 
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
 
DefaultTwoWayKey2StringMapper - Class in org.infinispan.loaders.jdbc.stringbased
Default implementation for TwoWayKey2StringMapper that knows how to handle all primitive wrapper keys and Strings.
DefaultTwoWayKey2StringMapper() - Constructor for class org.infinispan.loaders.jdbc.stringbased.DefaultTwoWayKey2StringMapper
 
defaultVisit(AbstractConfigurationBean) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
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.

defineConfiguration(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
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.EmbeddedCacheManager
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.

delegatePurgeExpired() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
delete() - Method in class org.infinispan.io.GridFile
 
delete(boolean) - Method in class org.infinispan.io.GridFile
 
deleteFile(String) - Method in class org.infinispan.lucene.InfinispanDirectory
deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
Deletes or releases a read-lock for the specified filename, so that if it was marked as deleted and no other InfinispanIndexInput instances are reading from it, then it will be effectively deleted.
deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
It will release a previously acquired readLock, or if no readLock was acquired it will mark the file to be deleted as soon as all pending locks are releases.
deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
doesn't do anything
deleteOrReleaseReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
It will release a previously acquired readLock, or if no readLock was acquired it will mark the file to be deleted as soon as all pending locks are releases.
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(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(InfinispanDirectory) - 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() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
destroy() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
destroy() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
destroy() - Method in class org.infinispan.demos.gridfs.GridStore
 
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
destroyObject(Object, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
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
 
DIR - Static variable in class org.infinispan.io.GridFile.Metadata
 
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
 
DistributedSegmentReadLocker - Class in org.infinispan.lucene.readlocks
DistributedSegmentReadLocker stores reference counters in the cache to keep track of the number of clients still needing to be able to read a segment.
DistributedSegmentReadLocker(Cache, String) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
 
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.
doFlush() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
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
 
dryRunNextServer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
Returns same value as RoundRobinBalancingStrategy.nextServer() without modifying indexes/state.
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
 
EARLIEST_EXPIRY_TIME - Static variable in class org.infinispan.loaders.cloud.CloudCacheStore
 
elementDecl(XSElementDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
elements() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns an enumeration of the values in this table.
EmbeddedCacheManager - Interface in org.infinispan.manager
EmbeddedCacheManager is an CacheManager that runs in the same JVM as the client.
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
 
endBatch(boolean) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
endBatch(boolean) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
endElement(String, String, String) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
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.
enqueueModificationsList(List<? extends Modification>) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
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 class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
entrySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
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.DefaultDataContainer
 
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.BoundedConcurrentHashMap
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.client.hotrod.impl.BinaryVersionedValue
 
equals(Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
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.ModificationsList
 
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.ChunkCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileListCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileMetadata
 
equals(Object) - Method in class org.infinispan.lucene.FileReadLockKey
 
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.server.websocket.CacheListener.ChannelNotifyParams
 
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.ByteArrayKey
 
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
 
ERROR_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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, EmbeddedCacheManager, 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(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
evict(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
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
 
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
EvictionThreadPolicy - Enum in org.infinispan.eviction
Supported eviction thread policy
EXCEPTION_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.infinispan.server.websocket.WebSocketServerHandler
 
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 class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
execute() - Method in class org.infinispan.client.hotrod.impl.operations.PingOperation
 
execute() - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
execute() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.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
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ContainsKeyOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.GetOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.GetWithVersionOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.PutIfAbsentOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.PutOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RemoveIfUnmodifiedOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RemoveOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ReplaceIfUnmodifiedOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ReplaceOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
ExecutorFactory - Interface in org.infinispan.executors
Used to configure and create executors
existModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
exists() - Method in class org.infinispan.io.GridFile
 
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
 
factory - Variable in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
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
 
FILE - Static variable in class org.infinispan.io.GridFile.Metadata
 
file - Variable in class org.infinispan.io.GridInputStream
 
file - Variable in class org.infinispan.io.GridOutputStream
 
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
 
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
FileListCacheKey - Class in org.infinispan.lucene
Cache key for a list with current files in cache
FileListCacheKey(String) - Constructor for class org.infinispan.lucene.FileListCacheKey
 
FileLookup - Class in org.infinispan.util
Holds the logic of looking up a file, in the following sequence: try to load it with the current thread's context ClassLoader if fails, the system ClassLoader if fails, try to load it as a file from the disk
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
filename(String) - Static method in class org.infinispan.io.GridFile
 
FileReadLockKey - Class in org.infinispan.lucene
Lucene's index segment files are chunked, for safe deletion of elements a read lock is implemented so that all chunks are deleted only after the usage counter is decremented to zero.
FileReadLockKey(String, String) - Constructor for class org.infinispan.lucene.FileReadLockKey
 
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
 
findSchemaInputStream(String) - Static method in class org.infinispan.config.InfinispanConfiguration
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
finishObjectInput(ObjectInput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Finish using the given ObjectInput.
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.marshall.StreamingMarshaller
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.client.hotrod
Defines all the flags available in the Hot Rod client that can influence the behavior of operations.
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.client.hotrod.impl.operations.HotRodOperation
 
flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
flags - Variable in class org.infinispan.context.impl.AbstractInvocationContext
 
flush() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
flush() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
flush() - Method in class org.infinispan.io.GridOutputStream
 
flush() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
flush() - Method in class org.infinispan.lucene.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
 
FORCE_RETURN_VALUES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
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

generate() - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
generateContents() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
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
 
GenericJBossMarshaller - Class in org.infinispan.marshall.jboss
A marshaller that makes use of JBoss Marshalling to serialize and deserialize objects.
GenericJBossMarshaller() - Constructor for class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
GenericJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.marshall.jboss
 
GenericJBossMarshaller.DebuggingExceptionListener() - Constructor for class org.infinispan.marshall.jboss.GenericJBossMarshaller.DebuggingExceptionListener
 
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() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
get(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
get(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
get(Object) - Method in interface org.infinispan.container.DataContainer
Retrieves a cached entry
get(Object) - Method in class org.infinispan.container.DefaultDataContainer
 
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(long, TimeUnit) - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
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.BoundedConcurrentHashMap
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
 
GET_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_VERSION - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_VERSION_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
getActivations() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
getAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getAddress() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getAddress() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the address associated with this RpcManager or null if not part of the cluster.
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
 
getAddress2KeysMapping() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getAdvancedCache() - Method in class org.infinispan.AbstractDelegatingCache
 
getAdvancedCache() - Method in interface org.infinispan.Cache
 
getAdvancedCache() - Method in class org.infinispan.CacheDelegate
 
getAdvancedCache() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getAdvancedCache() - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
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.tools.doclet.config.AbstractConfigHtmlGenerator
 
getAsInputStreamFromClassLoader(String) - Method in class org.infinispan.util.FileLookup
 
getAsyncExecutorFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAsyncListenerExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncListenerExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
 
getAsyncResponseMode(Configuration) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
 
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, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key.
getAtomicMap(Cache<MK, ?>, MK, boolean) - 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
 
getBalancer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
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.AbstractNonDelegatingJdbcCacheStoreConfig
 
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.LegacyKeySupportTypedProperties
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.util.TypedProperties
 
getBooleanProperty(String, boolean, 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
 
getBufferSize() - Method in class org.infinispan.lucene.FileMetadata
 
getBulk() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getBulk(int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getBulk() - Method in interface org.infinispan.client.hotrod.RemoteCache
Bulk get operations, returns all the entries within the remote cache.
getBulk(int) - Method in interface org.infinispan.client.hotrod.RemoteCache
Same as RemoteCache.getBulk(), but limits the returned set of values to the specified size.
getCache(String) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache(String, boolean) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache(boolean) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
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.CacheContainer
Retrieves the default cache associated with this cache container.
getCache(String) - Method in interface org.infinispan.manager.CacheContainer
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.client.hotrod.impl.RemoteCacheSupport
 
getCacheManager() - Method in class org.infinispan.ec2demo.CacheBuilder
 
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 class org.infinispan.manager.DefaultCacheManager
 
getCacheNames() - Method in interface org.infinispan.manager.EmbeddedCacheManager
If no named caches are registered, this method returns an empty set.
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(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
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
 
getChunkId() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the chunkId.
getChunkSize() - Method in class org.infinispan.io.GridFile
 
getChunkSize() - Method in class org.infinispan.io.GridFile.Metadata
 
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 class org.infinispan.manager.DefaultCacheManager
 
getClusterName() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClusterSize() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getCode() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getCoinToss() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
getCollocatedKey(K) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the same node as the supplied key.
getCollocatedKey(Object) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
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.AbstractLocalCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
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.AbstractConfigHtmlGenerator
Returns a list of classes inspected for configuration reference javadoc tags.
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() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getConfiguration() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
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
This method is used by the configuration parser to get a hold of the CacheLoader implementation's corresponding CacheLoaderConfig type.
getConfigurationClass() - Method in interface org.infinispan.loaders.CacheLoader
This method is used by the configuration parser to get a hold of the CacheLoader implementation's corresponding CacheLoaderConfig type.
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
 
getConfigurationClass() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
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.AbstractJdbcCacheStoreConfig
 
getConnectionPool() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConnectionUrl() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionUrl() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getConsistentHash() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
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
 
getData() - Method in class org.infinispan.util.ByteArrayKey
 
getDatabaseType() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
getDatabaseType() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
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
 
getDecoder() - Method in class org.infinispan.server.websocket.WebSocketServer
 
getDefaultConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefaultConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns default configuration for this CacheManager
getDefaultExecutorFactoryPoolSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
getEncoder() - Method in class org.infinispan.server.websocket.WebSocketServer
 
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
 
getEvictionThreadPolicy() - Method in class org.infinispan.config.Configuration
 
getEvictionWakeUpInterval() - Method in class org.infinispan.config.Configuration
Eviction thread wake up interval, in milliseconds.
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getExecutor(Properties) - Method in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in interface org.infinispan.executors.ExecutorFactory
 
getExitingNumberOfKeys() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getExpirationLifespan() - Method in class org.infinispan.config.Configuration
Expiration lifespan, in milliseconds
getExpirationMaxIdle() - Method in class org.infinispan.config.Configuration
Expiration max idle time, in milliseconds
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.AbstractNonDelegatingJdbcCacheStoreConfig
 
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
 
getFile(String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFile(String, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(String, String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFileName() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the fileName.
getFileName() - Method in class org.infinispan.lucene.FileCacheKey
Get the fileName.
getFileName() - Method in class org.infinispan.lucene.FileReadLockKey
Get the fileName.
getFilePointer() - Method in class org.infinispan.lucene.InfinispanIndexInput
 
getFilePointer() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
getFilePointer() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
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
 
getFlagInt() - Method in enum org.infinispan.client.hotrod.Flag
 
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
 
getForceReturnValues() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
Deprecated. 
getGlobalConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getGlobalConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns global configuration for this CacheManager
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
 
GetHandler - Class in org.infinispan.server.websocket.handlers
Cache "get" operation handler.
GetHandler() - Constructor for class org.infinispan.server.websocket.handlers.GetHandler
 
getHashId(Address) - Method in interface org.infinispan.distribution.ConsistentHash
Returns the value between 0 and the hash space limit, or hash id, for a particular address.
getHashId(Address) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
getHashId(Address) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
getHashId(Address) - Method in class org.infinispan.distribution.UnionConsistentHash
 
getHashSpace() - Method in interface org.infinispan.distribution.ConsistentHash
Returns the hash space constant for this consistent hash algorithm class.
getHashSpace() - Method in class org.infinispan.distribution.DefaultConsistentHash
 
getHashSpace() - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
getHashSpace() - Method in class org.infinispan.distribution.UnionConsistentHash
 
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
 
getHotRodClientProperties() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
getId() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
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
 
getIndexName() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileListCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileReadLockKey
Get the indexName.
getInput(String) - Method in class org.infinispan.io.GridFilesystem
 
getInput(File) - Method in class org.infinispan.io.GridFilesystem
 
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
Instantiates a class by first attempting a static factory method named getInstance() on the class and then falling back to an empty constructor.
getInstance(String) - Static method in class org.infinispan.util.Util
Instantiates a class based on the class name provided.
getInstanceStrict(Class<T>) - Static method in class org.infinispan.util.Util
Similar to Util.getInstance(Class) except that exceptions are propagated to the caller.
getInstanceStrict(String) - Static method in class org.infinispan.util.Util
Similar to Util.getInstance(String) except that exceptions are propagated to the caller.
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.LegacyKeySupportTypedProperties
 
getIntProperty(String, int) - Method in class org.infinispan.util.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.util.TypedProperties
 
getIntStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getIntStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getInvalidations() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
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
 
getJavascript() - Static method in class org.infinispan.server.websocket.WebSocketServer
 
getJGroupsAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
getJGroupsChannel(Properties) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
Retrieves a JGroups channel.
getJmxDomain() - Method in class org.infinispan.config.GlobalConfiguration
 
getJmxDomain(String, MBeanServer) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
getKey() - Method in interface org.infinispan.affinity.KeyGenerator
 
getKey() - Method in class org.infinispan.affinity.RndKeyGenerator
 
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
 
getKeyForAddress(Address) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the cluster node identified by address.
getKeyForAddress(Address) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getKeyMapping(String) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultKey2StringMapper
Deprecated.  
getKeyMapping(String) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultTwoWayKey2StringMapper
 
getKeyMapping(String) - Method in interface org.infinispan.loaders.jdbc.stringbased.TwoWayKey2StringMapper
 
getKeyMapping(String) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
This method has to perform the inverse transformation of the keys used in the Lucene Directory from String to object.
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
 
getKeysAddedInCurrentInvocation() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
getKeysAddedInCurrentInvocation() - Method in interface org.infinispan.context.InvocationContext
Retrieves a set of keys added to the context within the scope of the current ivocation up to the current point in time.
getKeySizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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() - Method in class org.infinispan.io.GridFile.Metadata
 
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.ModificationsList
 
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.client.hotrod.impl.RemoteCacheSupport
 
getListeners() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
getListeners() - Method in class org.infinispan.manager.DefaultCacheManager
 
getListeners() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getListeners() - Method in interface org.infinispan.notifications.Listenable
 
getLoadAllKeysBinarySql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadAllKeysSql() - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
getLoadAllKeysStringSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadNonExpiredAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadSomeRowsSql() - 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.InvertedLeaveTask
 
getLog() - Method in class org.infinispan.distribution.JoinTask
 
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.LegacyKeySupportTypedProperties
 
getLongProperty(String, long) - Method in class org.infinispan.util.TypedProperties
 
getLongProperty(String, long, boolean) - 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.client.hotrod.impl.ConfigurationProperties
 
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
 
getMaxNumberOfKeys() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
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 class org.infinispan.manager.DefaultCacheManager
 
getMembers() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
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
 
getModificationTime() - Method in class org.infinispan.io.GridFile.Metadata
 
getMyAddress() - Method in class org.infinispan.distribution.JoinTask
 
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.client.hotrod.impl.RemoteCacheImpl
 
getName() - Method in class org.infinispan.config.Configuration
 
getName() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getName() - Method in class org.infinispan.io.GridFile
 
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
 
getNewValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Retrieves the next interceptor in the chain.
getNextPosition() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
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
 
getNodeAddress() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
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
 
getNumberOfChunks() - Method in class org.infinispan.lucene.FileMetadata
 
getNumberOfEntries() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getNumberOfLocksAvailable() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumberOfLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the number of locks currently held.
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
 
getOldValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
GetOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "get" operation as described by Hot Rod protocol specification.
GetOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetOperation
 
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.
getOutput(String) - Method in class org.infinispan.io.GridFilesystem
 
getOutput(String, boolean) - Method in class org.infinispan.io.GridFilesystem
 
getOutput(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
 
getOutput(GridFile) - Method in class org.infinispan.io.GridFilesystem
 
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.AbstractLocalCommand
 
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
 
getPassivationCount() - Method in interface org.infinispan.eviction.PassivationManager
 
getPassivationCount() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
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
 
getPath() - Method in class org.infinispan.io.GridFile
Returns path of this file.
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.
getPingOnStartup() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
getProgrammaticMapping() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProperties() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
getProperty(String, String) - Static method in class org.infinispan.util.LegacyKeySupportSystemProperties
 
getProperty(String, String, String) - Static method in class org.infinispan.util.LegacyKeySupportSystemProperties
 
getProperty(String) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getProperty(String, String) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getProperty(String, String, boolean) - Method in class org.infinispan.util.TypedProperties
Get the property associated with the key, optionally applying string property replacement as defined in StringPropertyReplacer.replaceProperties(java.lang.String) to the result.
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
 
getProtocolVersion() - Static method in class org.infinispan.client.hotrod.Version
 
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, Class<?>...) - Method in class org.infinispan.query.QueryFactory
This is a simple method that will just return a CacheQuery, filtered according to a set of classes passed in.
getRaw() - Method in class org.infinispan.marshall.MarshalledValue
 
getRawBuffer() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the internal buffer array.
getReadOnlyAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key, for reading only.
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
 
getRemoteCacheManager() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the RemoteCacheManager that created this cache.
getRemoteCacheName() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
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
 
getRequestBalancingStrategy() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getRequestTimeout() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getResourceContent(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
getResourceLength(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
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.AbstractConfigHtmlGenerator
 
getRootElementName() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Name of the root element in the schema
getRootElementName() - 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
 
getSchemaFile() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Returns name of the schema file.
getSchemaFile() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
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
 
getServer(byte[]) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
getServer(byte[]) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
getServerAddress() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
getServerList() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getServers() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
getServers() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
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
 
getShutdownTimeout() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getSingleKey() - Method in class org.infinispan.commands.control.LockControlCommand
 
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
 
getStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
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
 
getStatsMap() - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatsMap() - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
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.client.hotrod.impl.RemoteCacheSupport
 
getStatus() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the state of the registry
getStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStatus() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
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
 
getStoredObject(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
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
 
getStringBuilder() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getStringMapping(Object) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultKey2StringMapper
Deprecated. Returns key.toString.
getStringMapping(Object) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultTwoWayKey2StringMapper
 
getStringMapping(Object) - Method in interface org.infinispan.loaders.jdbc.stringbased.Key2StringMapper
Must return an unique String for the supplied key.
getStringMapping(Object) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
 
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.AbstractNonDelegatingJdbcCacheStoreConfig
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
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.
getTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
getTitle() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getTitle() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
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(int) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
getTransport() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransport(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransport() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransport(byte[]) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
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
 
getTransportCount() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransportCount() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
getTransportFactory() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
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.ModificationsList
 
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.client.hotrod.impl.BinaryVersionedValue
 
getValue(Properties, String, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.PropsKeyedObjectPoolFactory
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getValue() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
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
getValueSizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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.client.hotrod.impl.BinaryVersionedValue
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getVersion() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
getVersion() - Method in class org.infinispan.manager.DefaultCacheManager
 
getVersion2ConsistentHash() - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
getVersioned(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersioned(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the VersionedValue associated to the supplied key param, or null if it doesn't exist.
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
 
getWithVersion(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
Returns null if the given key does not exist.
GetWithVersionOperation - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to getWithVersion operation as described by Hot Rod protocol specification.
GetWithVersionOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetWithVersionOperation
 
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, EmbeddedCacheManager) - 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
 
GridFile - Class in org.infinispan.io
Subclass of File to iterate through directories and files in a grid
GridFile.Metadata - Class in org.infinispan.io
 
GridFile.Metadata() - Constructor for class org.infinispan.io.GridFile.Metadata
 
GridFile.Metadata(int, long, int, byte) - Constructor for class org.infinispan.io.GridFile.Metadata
 
GridFilesystem - Class in org.infinispan.io
Entry point for GridFile and GridInputStream / GridOutputStream
GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>, int) - Constructor for class org.infinispan.io.GridFilesystem
Creates an instance.
GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>) - Constructor for class org.infinispan.io.GridFilesystem
 
GridInputStream - Class in org.infinispan.io
 
GridOutputStream - Class in org.infinispan.io
 
GridStore - Class in org.infinispan.demos.gridfs
 
GridStore(File) - Constructor for class org.infinispan.demos.gridfs.GridStore
 
gtxFactory - Variable in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 

H

handle(Bucket) - Method in interface org.infinispan.loaders.bucket.BucketBasedCacheStore.BucketHandler
Handles a bucket that is passed in.
handle(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
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.
handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.ListenerRegistration
 
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
 
handleMarshallingException(Throwable, Object) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller.DebuggingExceptionListener
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.GetHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.NotifyHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.PutHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.RemoveHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in interface org.infinispan.server.websocket.OpHandler
Handle a websocket channel operation.
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
 
handleUnmarshallingException(Throwable, Class<?>) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller.DebuggingExceptionListener
 
handleUnmarshallingException(Throwable) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller.DebuggingExceptionListener
 
handleViewChange(ViewChangedEvent) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
handleViewChange(ViewChangedEvent) - Method in class org.infinispan.affinity.ListenerRegistration
 
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
 
hash(byte[]) - Static method in class org.infinispan.util.hash.MurmurHash2
Hashes a byte array efficiently.
hash(int) - Static method in class org.infinispan.util.hash.MurmurHash2
An incremental version of the hash function, that spreads a pre-calculated hash code, such as one derived from Object.hashCode().
hash(Object) - Static method in class org.infinispan.util.hash.MurmurHash2
A helper that calculates the hashcode of an object, choosing the optimal mechanism of hash calculation after considering the type of the object (byte array, String or Object).
HASH_FUNCTION_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
hashCode() - Method in class org.infinispan.client.hotrod.impl.BinaryVersionedValue
 
hashCode() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
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.ModificationsList
 
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.ChunkCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileListCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileMetadata
 
hashCode() - Method in class org.infinispan.lucene.FileReadLockKey
 
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.server.websocket.CacheListener.ChannelNotifyParams
 
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.ByteArrayKey
 
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.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
 
HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get hits.
hookBehavior - Variable in class org.infinispan.config.GlobalConfiguration.ShutdownType
 
HOTROD_CLIENT_PROPERTIES - Static variable in class org.infinispan.client.hotrod.RemoteCacheManager
 
HOTROD_STRING_CHARSET - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
HOTROD_VERSION - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
HotRodClientException - Exception in org.infinispan.client.hotrod.exceptions
Base class for exceptions reported by the hot rod client.
HotRodClientException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodConstants - Interface in org.infinispan.client.hotrod.impl.protocol
Defines constants defined by Hot Rod specifications.
HotRodOperation - Class in org.infinispan.client.hotrod.impl.operations
Generic Hot Rod operation.
HotRodOperation(Flag[], byte[], AtomicInteger) - Constructor for class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
HotRodOperations - Interface in org.infinispan.client.hotrod.impl.protocol
Defines the Hot Rod operations as described in the protocol spec: http://community.jboss.org/wiki/HotRodProtocol
HotRodTimeoutException - Exception in org.infinispan.client.hotrod.exceptions
Signals an remote timeout(due to locking) in the infinispan server.
HotRodTimeoutException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
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
 
includeKey(Object, Set<Object>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
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
 
INFINISPAN_WS_JS_FILENAME - Static variable in class org.infinispan.server.websocket.WebSocketServer
 
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.

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
An implementation of Lucene's Directory which uses Infinispan to store Lucene indexes.
InfinispanDirectory(Cache, String, LockFactory, int, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache, String, LockFactory, int) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache, String, int, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache, String, LockFactory) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache, String, int) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache, String) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanFluDemo - Class in org.infinispan.ec2demo
 
InfinispanFluDemo() - Constructor for class org.infinispan.ec2demo.InfinispanFluDemo
 
InfinispanIndexInput - Class in org.infinispan.lucene
Responsible for reading from InfinispanDirectory
InfinispanIndexInput(AdvancedCache, FileCacheKey, FileMetadata, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanIndexInput
 
InfinispanIndexOutput - Class in org.infinispan.lucene
Responsible for writing to a Directory
InfinispanIndexOutput(AdvancedCache, FileCacheKey, int, FileListOperations) - Constructor for class org.infinispan.lucene.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(LinkedHashMap<InetSocketAddress, Integer>, int, int) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
init(ConfigurationProperties) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
init(LinkedHashMap<InetSocketAddress, Integer>, int, int) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
init(Marshaller, ExecutorService, OperationsFactory, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
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(ServletConfig) - Method in class org.infinispan.demos.gridfs.CacheManagerHolder
 
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<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.AbstractCacheLoader
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.AbstractCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Used to initialize a cache loader.
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in interface org.infinispan.loaders.CacheLoader
Used to initialize a cache loader.
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller, BlobStoreContext, BlobStore, AsyncBlobStore, boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.file.FileCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
init(CacheLoaderConfig, Cache, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
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(EvictionManager) - Method in class org.infinispan.container.DefaultDataContainer
 
initialize(ScheduledExecutorService, Configuration, DataContainer, CacheLoaderManager, CacheNotifier, LockManager, PassivationManager, InvocationContextContainer) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
initialize(AdvancedCache, GlobalConfiguration) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
initialize(GlobalConfiguration, StreamingMarshaller, ExecutorService, InboundInvocationHandler, CacheManagerNotifier) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
initialize(GlobalConfiguration, StreamingMarshaller, 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, EmbeddedCacheManager) - 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
 
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
 
initMetadata() - Method in class org.infinispan.io.GridFile
 
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(CacheLoaderManager, CacheNotifier, Configuration) - Method in class org.infinispan.eviction.PassivationManagerImpl
 
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, StreamingMarshaller, Configuration) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
inject(RemoteCommandsFactory) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
inject(StreamingMarshaller) - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
inject(ClassLoader, RemoteCommandsFactory) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
inject(GlobalComponentRegistry, StreamingMarshaller) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
inject(DistributionManager) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
injectCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
injectDependencies(EvictionManager, InvocationContextContainer, CommandsFactory, InterceptorChain, Configuration, CacheNotifier, ComponentRegistry, TransactionManager, BatchContainer, RpcManager, DataContainer, StreamingMarshaller, ResponseGenerator, DistributionManager, EmbeddedCacheManager, 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, StreamingMarshaller, 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
 
injectLockManager(LockManager) - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
injectMarshaller(StreamingMarshaller) - 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.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() - Constructor for class org.infinispan.container.entries.InternalEntryFactory
 
interruptProcessingThread() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Tries to interrupt the processing thread.
INVALID_MAGIC_OR_MESSAGE_ID_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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(List<Address>, ConsistentHash, ConsistentHash) - Method in class org.infinispan.distribution.RehashTask
 
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
 
InvalidResponseException - Exception in org.infinispan.client.hotrod.exceptions
Signals an internal protocol error.
InvalidResponseException() - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvertedLeaveTask - Class in org.infinispan.distribution
A task to handle rehashing for when a node leaves the cluster
InvertedLeaveTask(DistributionManagerImpl, RpcManager, Configuration, CommandsFactory, DataContainer, List<Address>, List<Address>, boolean) - Constructor for class org.infinispan.distribution.InvertedLeaveTask
 
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() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl.KeyGeneratorWorker
 
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
 
isAlive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl.KeyGeneratorWorker
 
isAllowDuplicateDomains() - Method in class org.infinispan.config.GlobalConfiguration
 
isAlwaysProvideInMemoryState() - Method in class org.infinispan.config.Configuration
 
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.client.hotrod.impl.async.NotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
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(String, String) - Static method in class org.infinispan.io.GridFile
Verifies whether child is a child (dir or file) of parent
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
 
isCompress() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
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 class org.infinispan.manager.DefaultCacheManager
 
isCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
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.
isDirectory() - Method in class org.infinispan.io.GridFile
 
isDirectory() - Method in class org.infinispan.io.GridFile.Metadata
 
isDistributed() - Method in enum org.infinispan.config.Configuration.CacheMode
 
isDistributed() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
isDone() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
isDone() - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
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.client.hotrod.impl.RemoteCacheSupport
 
isEmpty() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
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.BoundedConcurrentHashMap
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.ReadOnlyDataContainerBackedKeySet
 
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 enum org.infinispan.eviction.EvictionStrategy
 
isEnabled() - Method in interface org.infinispan.eviction.PassivationManager
 
isEnabled() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
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
 
isFile() - Method in class org.infinispan.io.GridFile
 
isFile() - Method in class org.infinispan.io.GridFile.Metadata
 
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
 
isKeyGeneratorThreadActive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isKeyGeneratorThreadAlive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
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
 
isManageConnectionFactory() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
If this method returns false, then the connection factory should not be created by the JdbcStringBasedCacheStore, but will be injected through JdbcStringBasedCacheStore.doConnectionFactoryInitialization(org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory)
isManagedResource() - Method in class org.infinispan.jmx.ResourceDMBean
 
isMarkedForRollback() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Once marked for rollback, the call to DeadlockDetectingGlobalTransaction.interruptProcessingThread() will be ignored.
isMarshallable(Object) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
isMarshallable(Object) - Method in interface org.infinispan.marshall.Marshaller
A method that checks whether the given object is marshallable as per the rules of this marshaller.
isMarshallable(Object) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
isNeedsToRejoin() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
isNeedsToRejoin() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
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
 
ISPN_NS - Static variable in class org.infinispan.config.parsing.NamespaceFilter
 
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
 
isStarted() - Method in interface org.infinispan.affinity.KeyAffinityService
Checks weather or not the service is started.
isStarted() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isStarted() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
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
Deprecated. Returns true if this is an primitive wrapper, false otherwise.
isSupportedType(Class) - Method in class org.infinispan.loaders.jdbc.stringbased.DefaultTwoWayKey2StringMapper
 
isSupportedType(Class) - Method in interface org.infinispan.loaders.jdbc.stringbased.Key2StringMapper
Do we support this key type?
isSupportedType(Class) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
 
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
 
isTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
isTcpNoDelay() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
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
 
isUpdated() - Method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
 
isUseAsyncMarshalling() - Method in class org.infinispan.config.Configuration
 
isUseDefaultRemoteCache() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
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
 
isUsingPreload() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
isValid() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
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.DefaultDataContainer
 
iterator(int) - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a QueryIterator with a given integer parameter - the fetchSize.
iterator() - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a QueryIterator.
iterator() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
iterator(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
iterator() - Method in class org.infinispan.tools.schema.TreeNode
 
iterator() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
iterator() - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
iterator() - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
iterator() - Method in class org.infinispan.util.FastCopyHashMap.Values
 
iterator() - Method in class org.infinispan.util.ImmutableListCopy
 
iterator() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
iterator() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns an iterator over the elements in this set.

J

JaxbSchemaGenerator - Class in org.infinispan.util
Generates XML schema using JAXB annotations from our configuration class hierarchy.
JaxbSchemaGenerator() - Constructor for class org.infinispan.util.JaxbSchemaGenerator
 
JBossMarshaller - Class in org.infinispan.marshall.jboss
A specialized form of the GenericJBossMarshaller, making use of a custom object table for types internal to Infinispan.
JBossMarshaller() - Constructor for class org.infinispan.marshall.jboss.JBossMarshaller
 
JBossStandaloneJTAManagerLookup - Class in org.infinispan.transaction.lookup
JTA standalone TM lookup.
JBossStandaloneJTAManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
JBossTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Uses JNDI to look-up the TransactionManager instance from "java:/TransactionManager".
JBossTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossTransactionManagerLookup
 
JdbcBinaryCacheStore - Class in org.infinispan.loaders.jdbc.binary
BucketBasedCacheStore implementation that will store all the buckets as rows in database, each row corresponding to a bucket.
JdbcBinaryCacheStore() - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
JdbcBinaryCacheStoreConfig - Class in org.infinispan.loaders.jdbc.binary
Defines available configuration elements for JdbcBinaryCacheStore.
JdbcBinaryCacheStoreConfig(boolean) - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcBinaryCacheStoreConfig(ConnectionFactoryConfig, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcBinaryCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcMixedCacheStore - Class in org.infinispan.loaders.jdbc.mixed
Cache store that combines functionality of JdbcBinaryCacheStore and JdbcStringBasedCacheStore.
JdbcMixedCacheStore() - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
JdbcMixedCacheStoreConfig - Class in org.infinispan.loaders.jdbc.mixed
Configuration for JdbcMixedCacheStore.
JdbcMixedCacheStoreConfig(ConnectionFactoryConfig, TableManipulation, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
JdbcMixedCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
JdbcStringBasedCacheStore - Class in org.infinispan.loaders.jdbc.stringbased
CacheStore implementation that stores the entries in a database.
JdbcStringBasedCacheStore() - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
JdbcStringBasedCacheStoreConfig - Class in org.infinispan.loaders.jdbc.stringbased
Configuration for JdbcStringBasedCacheStore cache store.
JdbcStringBasedCacheStoreConfig(ConnectionFactoryConfig, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcStringBasedCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcStringBasedCacheStoreConfig(boolean) - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcUtil - Class in org.infinispan.loaders.jdbc
Contains common methods used by JDBC CacheStores.
JdbcUtil() - Constructor for class org.infinispan.loaders.jdbc.JdbcUtil
 
JdbmCacheStore - Class in org.infinispan.loaders.jdbm
A persistent CacheLoader based on the JDBM project.
JdbmCacheStore() - Constructor for class org.infinispan.loaders.jdbm.JdbmCacheStore
 
JdbmCacheStoreConfig - Class in org.infinispan.loaders.jdbm
Configures JdbmCacheStore.
JdbmCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
JdbmSerializer - Class in org.infinispan.loaders.jdbm
Uses the configured (runtime) StreamingMarshaller of the cache.
JdbmSerializer(StreamingMarshaller) - Constructor for class org.infinispan.loaders.jdbm.JdbmSerializer
Constructs a new JdbmSerializer.
JDK_MAPS - Static variable in interface org.infinispan.marshall.Ids
 
JDK_SETS - Static variable in interface org.infinispan.marshall.Ids
 
JDKLogImpl - Class in org.infinispan.util.logging
Logger that delivers messages to a JDK logger
JDKLogImpl(String) - Constructor for class org.infinispan.util.logging.JDKLogImpl
 
JGROUPS_ADDRESS - Static variable in interface org.infinispan.marshall.Ids
 
JGroupsAddress - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups Address
JGroupsAddress() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
JGroupsAddress(Address) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
JGroupsAddress.Externalizer - Class in org.infinispan.remoting.transport.jgroups
 
JGroupsAddress.Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
JGroupsChannelLookup - Interface in org.infinispan.remoting.transport.jgroups
A hook to pass in a JGroups channel.
JGroupsDistSync - Class in org.infinispan.remoting.transport.jgroups
A DistributedSync based on JGroups' FLUSH protocol
JGroupsDistSync() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
JGroupsResponseFilterAdapter - Class in org.infinispan.remoting.transport.jgroups
Acts as a bridge between JGroups RspFilter and ResponseFilter.
JGroupsResponseFilterAdapter(ResponseFilter) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
Creates an instance of the adapter
JGroupsStackParser - Class in org.infinispan.config.parsing
The purpose of this class is to parse the jgroups configuration from the config file into an compact string that can be passed as a config to the channel.
JGroupsStackParser() - Constructor for class org.infinispan.config.parsing.JGroupsStackParser
 
JGroupsTransport - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups transport.
JGroupsTransport(Channel) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
This form is used when the transport is created by an external source and passed in to the GlobalConfiguration.
JGroupsTransport() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
JMX_RESOURCE_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
JmxComponent - Class in org.infinispan.tools.doclet.jmx
A JMX Component
JmxComponent() - Constructor for class org.infinispan.tools.doclet.jmx.JmxComponent
 
JmxDoclet - Class in org.infinispan.tools.doclet.jmx
A Doclet that generates a guide to all JMX components exposed by Infinispan
JmxDoclet() - Constructor for class org.infinispan.tools.doclet.jmx.JmxDoclet
 
jmxDomain - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
JmxDomainConflictException - Exception in org.infinispan.jmx
 
JmxDomainConflictException(String) - Constructor for exception org.infinispan.jmx.JmxDomainConflictException
 
JmxHtmlGenerator - Class in org.infinispan.tools.doclet.jmx
 
JmxHtmlGenerator(String, String, String, String, String, String, List<String>, List<MBeanComponent>) - Constructor for class org.infinispan.tools.doclet.jmx.JmxHtmlGenerator
 
JmxStatisticsExposer - Interface in org.infinispan.jmx
Interface containing common cache management operations
JmxStatsCommandInterceptor - Class in org.infinispan.interceptors.base
Base class for all the interceptors exposing management statistics.
JmxStatsCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
JOIN_COMPLETE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
JoinTask - Class in org.infinispan.distribution
5.
JoinTask(RpcManager, CommandsFactory, Configuration, DataContainer, DistributionManagerImpl) - Constructor for class org.infinispan.distribution.JoinTask
 
jumpToResult(int) - Method in class org.infinispan.query.impl.EagerIterator
Jumps to a given index in the list of results.
jumpToResult(int) - Method in class org.infinispan.query.impl.LazyIterator
 
jumpToResult(int) - Method in interface org.infinispan.query.QueryIterator
Jumps to a specific index in the iterator.

K

key - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
key - Variable in class org.infinispan.commands.read.AbstractDataCommand
 
key - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
KEY - Static variable in interface org.infinispan.server.websocket.OpHandler
 
Key2StringMapper - Interface in org.infinispan.loaders.jdbc.stringbased
Defines the logic of mapping a key object to a String.
KEY_DOES_NOT_EXIST_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
KEY_SIZE_ESTIMATE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
keyAddedInCurrentInvocation(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Records that a key has been added.
KeyAffinityService<K> - Interface in org.infinispan.affinity
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
KeyAffinityServiceFactory - Class in org.infinispan.affinity
Factory for KeyAffinityService.
KeyAffinityServiceFactory() - Constructor for class org.infinispan.affinity.KeyAffinityServiceFactory
 
KeyAffinityServiceImpl - Class in org.infinispan.affinity
Implementation of KeyAffinityService.
KeyAffinityServiceImpl(Executor, Cache, KeyGenerator, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.KeyAffinityServiceImpl
 
KeyAffinityServiceImpl.KeyGeneratorWorker - Class in org.infinispan.affinity
 
KeyAffinityServiceImpl.KeyGeneratorWorker() - Constructor for class org.infinispan.affinity.KeyAffinityServiceImpl.KeyGeneratorWorker
 
KeyGenerator<K> - Interface in org.infinispan.affinity
Used for generating keys; used by KeyAffinityService to generate the affinity keys.
keys - Variable in class org.infinispan.commands.write.InvalidateCommand
 
keys() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns an enumeration of the keys in this table.
keysAddedInCurrentInvocation - Variable in class org.infinispan.context.impl.AbstractInvocationContext
 
keySet() - Method in class org.infinispan.AbstractDelegatingCache
 
keySet() - Method in class org.infinispan.atomic.AtomicHashMap
 
keySet() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
keySet() - Method in interface org.infinispan.Cache
Returns a set view of the keys contained in this cache.
keySet() - Method in class org.infinispan.CacheDelegate
 
keySet() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
keySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
keySet() - Method in interface org.infinispan.container.DataContainer
Returns a set of keys in the container.
keySet() - Method in class org.infinispan.container.DefaultDataContainer
 
keySet - Variable in class org.infinispan.util.AbstractMap
 
keySet() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
 
keySet() - Method in interface org.infinispan.util.BidirectionalMap
 
keySet() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.infinispan.util.FastCopyHashMap
 
KeySetCommand - Class in org.infinispan.commands.read
KeySetCommand.
KeySetCommand(DataContainer) - Constructor for class org.infinispan.commands.read.KeySetCommand
 
keyToString(Object) - Static method in class org.infinispan.query.backend.KeyTransformationHandler
 
KeyTransformationHandler - Class in org.infinispan.query.backend
This transforms arbitrary keys to a String which can be used by Lucene as a document identifier, and vice versa.
KeyTransformationHandler() - Constructor for class org.infinispan.query.backend.KeyTransformationHandler
 
KnownComponentNames - Class in org.infinispan.factories
Holder for known named component names.
KnownComponentNames() - Constructor for class org.infinispan.factories.KnownComponentNames
 

L

l1 - Variable in class org.infinispan.config.Configuration.ClusteringType
 
last() - Method in class org.infinispan.query.impl.AbstractIterator
 
last() - Method in interface org.infinispan.query.QueryIterator
Jumps to the last result
lastAsyncProcessorShutsDownExecutor - Variable in class org.infinispan.loaders.decorators.AsyncStore
 
lastIndexOf(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
lastModified - Variable in class org.infinispan.remoting.MIMECacheEntry
The date the entry was created...
lazyIterator(int) - Method in interface org.infinispan.query.CacheQuery
Lazily loads the results from the Query as a QueryIterator with a given integer parameter - the fetchSize.
lazyIterator() - Method in interface org.infinispan.query.CacheQuery
Calls the CacheQuery.lazyIterator(int fetchSize) method but passes in a default 1 as a parameter.
lazyIterator() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
lazyIterator(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
LazyIterator - Class in org.infinispan.query.impl
Implementation for QueryIterator.
LazyIterator(DocumentExtractor, Cache, IndexSearcher, SearchFactoryImplementor, int, int, int) - Constructor for class org.infinispan.query.impl.LazyIterator
 
LegacyKeySupportSystemProperties - Class in org.infinispan.util
A wrapper around system properties that supports legacy keys
LegacyKeySupportSystemProperties() - Constructor for class org.infinispan.util.LegacyKeySupportSystemProperties
 
LegacyKeySupportTypedProperties - Class in org.infinispan.util
An extension of TypedProperties that has support for legacy keys.
LegacyKeySupportTypedProperties(Properties, Map<String, String>) - Constructor for class org.infinispan.util.LegacyKeySupportTypedProperties
 
LegacyKeySupportTypedProperties(Map<String, String>) - Constructor for class org.infinispan.util.LegacyKeySupportTypedProperties
 
length() - Method in class org.infinispan.io.GridFile
 
length() - Method in class org.infinispan.lucene.InfinispanIndexInput
 
length() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
length() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
levelOrderTraverse(TreeNode) - Method in class org.infinispan.tools.schema.AbstractTreeWalker
 
Lifecycle - Interface in org.infinispan.lifecycle
Lifecycle interface that defines the lifecycle of components
LifecycleManager - Class in org.infinispan.query.impl
 
LifecycleManager() - Constructor for class org.infinispan.query.impl.LifecycleManager
 
lifespan - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
lifespan - Variable in class org.infinispan.config.Configuration.ExpirationType
 
lifespan - Variable in class org.infinispan.config.Configuration.L1Type
 
LINKED_LIST - Static variable in interface org.infinispan.marshall.Ids
 
LinkedListExternalizer - Class in org.infinispan.marshall.exts
LinkedListExternalizer.
LinkedListExternalizer() - Constructor for class org.infinispan.marshall.exts.LinkedListExternalizer
 
list() - Method in class org.infinispan.io.GridFile
 
list(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
list() - Method in class org.infinispan.lucene.InfinispanDirectory
list() - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a list.
list() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
listAll() - Method in class org.infinispan.lucene.InfinispanDirectory
new name for list() in Lucene 3.0
listAllDocuments() - Method in class org.infinispan.lucenedemo.DemoActions
Returns a list of the values of all stored fields
listAllMembers() - Method in class org.infinispan.lucenedemo.DemoActions
Returns a list of Addresses of all members in the cluster
Listenable - Interface in org.infinispan.notifications
Interface that denotes that the implementation can have listeners attached to it.
Listener - Annotation Type in org.infinispan.notifications
Class-level annotation used to annotate an object as being a valid cache listener.
ListenerRegistration - Class in org.infinispan.affinity
Used for registering various cache notifications.
ListenerRegistration(KeyAffinityServiceImpl) - Constructor for class org.infinispan.affinity.ListenerRegistration
 
listenersMap - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
listFiles() - Method in class org.infinispan.io.GridFile
 
listFiles(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
listFiles(FileFilter) - Method in class org.infinispan.io.GridFile
 
listIterator() - Method in class org.infinispan.util.ImmutableListCopy
 
listIterator(int) - Method in class org.infinispan.util.ImmutableListCopy
 
listStoredValuesMatchingQuery(Query) - Method in class org.infinispan.lucenedemo.DemoActions
Runs a Query and returns the stored field for each matching document
load(Object) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Loads an entry mapped to by a given key.
load(int) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
 
load(Object) - Method in interface org.infinispan.loaders.CacheLoader
Loads an entry mapped to by a given key.
load(int) - Method in interface org.infinispan.loaders.CacheLoader
Loads up to a specific number of entries.
load(Object) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(int) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(int) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
load(int) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
load(Object) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
load(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
load(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
load(int) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
load(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
load(int) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
load(Object) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
load(int) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
loadAll() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Loads all entries in the loader.
loadAll() - Method in interface org.infinispan.loaders.CacheLoader
Loads all entries in the loader.
loadAll() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAll() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAll() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAll() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
loadAll() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
loadAll() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAll() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
 
loadAllKeys(Set<Object>) - Method in interface org.infinispan.loaders.CacheLoader
Loads a set of all keys, excluding a filter set.
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllKeysProcess(ResultSet, Set<Object>, Set<Object>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllKeysSupport(Set<Object>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllLockSafe() - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllProcess(ResultSet, Set<InternalCacheEntry>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllSupport(boolean) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadBucket(String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Loads a Bucket from the store, based on the hash code of the bucket.
loadBucket(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
loadBucket(String) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadBucket(File) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadBucket(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadBucketContainingKey(String) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadClass(String) - Static method in class org.infinispan.util.Util
Loads the specified class using this class's classloader, or, if it is null (i.e.
loadClassStrict(String) - Static method in class org.infinispan.util.Util
Similar to Util.loadClass(String) except that any ClassNotFoundExceptions experienced is propagated to the caller.
loader - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Loads an entry from a Bucket, locating the relevant Bucket using the key's hash code.
loadLockSafe(int) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadLockSafe(int) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadLockSafe(int) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadLockSafe(int) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadModuleProperties(String) - Static method in class org.infinispan.util.ModuleProperties
 
loadResourceAsStream(String) - Static method in class org.infinispan.util.Util
 
loadSome(int) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
LocalCommand - Interface in org.infinispan.commands
This is a marker interface to indicate that such commands will never be replicated and hence will not return any valid command IDs.
LocalLockMergingSegmentReadLocker - Class in org.infinispan.lucene.readlocks
LocalLockMergingSegmentReadLocker decorates the DistributedSegmentReadLocker to minimize remote operations in case several IndexReaders are opened on the same InfinispanDirectory.
LocalLockMergingSegmentReadLocker(Cache, String) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Create a new LocalLockMergingSegmentReadLocker for specified cache and index name.
LocalQueryInterceptor - Class in org.infinispan.query.backend

This class is an interceptor that will index data only if it has come from a local source.

LocalQueryInterceptor() - Constructor for class org.infinispan.query.backend.LocalQueryInterceptor
 
LocalTxInvocationContext - Class in org.infinispan.context.impl
Invocation context to be used for locally originated transactions.
LocalTxInvocationContext() - Constructor for class org.infinispan.context.impl.LocalTxInvocationContext
 
locate(Object, int) - Method in interface org.infinispan.distribution.ConsistentHash
Locates a key, given a replication count (number of copies).
locate(Object, int) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
locate(Object) - Method in interface org.infinispan.distribution.DistributionManager
Locates a key in a cluster.
locate(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locate(Object, int) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
locate(Object, int) - Method in class org.infinispan.distribution.UnionConsistentHash
 
locateAll(Collection<Object>, int) - Method in class org.infinispan.distribution.AbstractConsistentHash
 
locateAll(Collection<Object>, int) - Method in interface org.infinispan.distribution.ConsistentHash
The logical equivalent of calling ConsistentHash.locate(Object, int) multiple times for each key in the collection of keys.
locateAll(Collection<Object>) - Method in interface org.infinispan.distribution.DistributionManager
Locates a list of keys in a cluster.
locateAll(Collection<Object>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateKey(String) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
lock(K) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
lock(K) - Method in interface org.infinispan.AdvancedCache
Locks a given key eagerly across cache nodes in a cluster.
lock(Collection<? extends K>) - Method in interface org.infinispan.AdvancedCache
Locks collections of keys eagerly across cache nodes in a cluster.
lock(K) - Method in class org.infinispan.CacheDelegate
 
lock(Collection<? extends K>) - Method in class org.infinispan.CacheDelegate
 
lock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
LOCK_CONTROL_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
lockAcquisitionTimeout - Variable in class org.infinispan.config.Configuration.LockingType
 
lockAndRecord(Object, InvocationContext) - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
lockAndRecord(Object, InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Acquires a lock of type lockType, on a specific entry in the cache.
lockAndRecord(Object, InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
LockContainer - Interface in org.infinispan.util.concurrent.locks.containers
A container for locks
lockContainer - Variable in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
LockControlCommand - Class in org.infinispan.commands.control
LockControlCommand is a command that enables distributed locking across infinispan nodes.
LockControlCommand() - Constructor for class org.infinispan.commands.control.LockControlCommand
 
LockControlCommand(Collection<Object>, String) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
LockControlCommand(Collection<Object>, String, boolean) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
lockForReading(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Acquires read lock on the given key.
lockForWriting(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Acquires write lock on the given key.
LockingInterceptor - Class in org.infinispan.interceptors
Interceptor to implement MVCC functionality.
LockingInterceptor() - Constructor for class org.infinispan.interceptors.LockingInterceptor
 
lockInterruptibly() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
LockManager - Interface in org.infinispan.util.concurrent.locks
An interface to deal with all aspects of acquiring and releasing locks for cache entries.
LockManagerFactory - Class in org.infinispan.factories
Factory class that creates instances of LockManager.
LockManagerFactory() - Constructor for class org.infinispan.factories.LockManagerFactory
 
LockManagerImpl - Class in org.infinispan.util.concurrent.locks
Handles locks for the MVCC based LockingInterceptor
LockManagerImpl() - Constructor for class org.infinispan.util.concurrent.locks.LockManagerImpl
 
locks - Variable in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
LockSupportCacheStore - Class in org.infinispan.loaders
This class extends AbstractCacheStore adding lock support for consistently accessing stored data.
LockSupportCacheStore() - Constructor for class org.infinispan.loaders.LockSupportCacheStore
 
LockSupportCacheStoreConfig - Class in org.infinispan.loaders
Adds configuration support for LockSupportCacheStore.
LockSupportCacheStoreConfig() - Constructor for class org.infinispan.loaders.LockSupportCacheStoreConfig
 
log - Variable in class org.infinispan.config.AbstractConfigurationBean
 
log - Variable in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
log - Variable in class org.infinispan.factories.AbstractComponentFactory
 
log - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
log - Static variable in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
log - Variable in class org.infinispan.query.impl.CacheQueryImpl
 
log - Variable in class org.infinispan.tools.schema.AbstractTreeWalker
 
log - Static variable in class org.infinispan.transaction.tm.DummyTransactionManager
 
Log - Interface in org.infinispan.util.logging
Infinispan's log abstraction layer.
Log4JLogImpl - Class in org.infinispan.util.logging
Logger that delivers messages to a Log4J logger
Log4JLogImpl(String) - Constructor for class org.infinispan.util.logging.Log4JLogImpl
 
logAndThrow(Exception, String) - Static method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
logAndThrow(Exception, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
logCommit(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionLog
 
logErrorAndThrowExceptionIfNeeded(int, TransportException) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
LogFactory - Class in org.infinispan.util.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.util.logging.LogFactory
 
logIfNeeded(WriteCommand) - Method in interface org.infinispan.distribution.TransactionLogger
If logging is enabled, will log the command and return true.
logIfNeeded(PrepareCommand) - Method in interface org.infinispan.distribution.TransactionLogger
Logs a PrepareCommand if needed.
logIfNeeded(CommitCommand) - Method in interface org.infinispan.distribution.TransactionLogger
Logs a CommitCommand if needed.
logIfNeeded(RollbackCommand) - Method in interface org.infinispan.distribution.TransactionLogger
Logs a RollbackCommand if needed.
logIfNeeded(Collection<WriteCommand>) - Method in interface org.infinispan.distribution.TransactionLogger
If logging is enabled, will log the commands and return true.
logIfNeeded(WriteCommand) - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
logIfNeeded(PrepareCommand) - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
logIfNeeded(CommitCommand) - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
logIfNeeded(RollbackCommand) - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
logIfNeeded(Collection<WriteCommand>) - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
logNoTxWrite(WriteCommand) - Method in class org.infinispan.transaction.TransactionLog
 
logOnePhaseCommit(GlobalTransaction, WriteCommand[]) - Method in class org.infinispan.transaction.TransactionLog
 
logPrepare(PrepareCommand) - Method in class org.infinispan.transaction.TransactionLog
 
lookedUpEntries - Variable in class org.infinispan.context.impl.NonTxInvocationContext
 
lookupComponent(Class, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
lookupComponent(Class, String) - Method in class org.infinispan.factories.ComponentRegistry
 
lookupEntry(Object) - Method in interface org.infinispan.context.EntryLookup
Retrieves an entry from the collection of looked up entries in the current scope.
lookupEntry(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
lookupEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
lookupEntry(Object) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
lookupEntry(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
lookupFile(String) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
lookupFile(String) - Method in class org.infinispan.util.FileLookup
Looks up the file, see : FileLookup.
lookupFileLocation(String) - Method in class org.infinispan.util.FileLookup
 
lookupLocalComponent(Class, String) - Method in class org.infinispan.factories.ComponentRegistry
 
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
A mechanism to loop over all buckets in the cache store.
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
LuceneKey2StringMapper - Class in org.infinispan.lucene
To configure a JdbcStringBasedCacheStoreConfig for the Lucene Directory, use this Key2StringMapper implementation.
LuceneKey2StringMapper() - Constructor for class org.infinispan.lucene.LuceneKey2StringMapper
 

M

main(String[]) - Static method in class org.infinispan.config.parsing.ConfigFilesConvertor
usage : java org.jboss.cache.config.parsing.ConfigFilesConvertor -Dsource=config-2.x.xml -Ddestination=config-3.x.xnl
main(String[]) - Static method in class org.infinispan.demo.InfinispanDemo
 
main(String[]) - Static method in class org.infinispan.demos.directory.FilesystemDirectory
 
main(String[]) - Static method in class org.infinispan.ec2demo.InfinispanFluDemo
 
main(String[]) - Static method in class org.infinispan.lucenedemo.DemoDriver
 
main(String[]) - Static method in class org.infinispan.tools.jopr.RhqPluginXmlGenerator
 
main(String[]) - Static method in class org.infinispan.util.JaxbSchemaGenerator
 
main(String[]) - Static method in class org.infinispan.Version
Prints version information.
makeLock(String) - Method in class org.infinispan.lucene.locking.BaseLockFactory
makeLock(String) - Method in class org.infinispan.lucene.locking.TransactionalLockFactory
makeObject(Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
manageConnectionFactory - Variable in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
ManagedAttribute - Annotation Type in org.infinispan.jmx.annotations
Indicates that a public method or a field (any visibility) in an MBean class defines an MBean attribute.
ManagedConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Connection factory that can be used when on managed environments, like application servers.
ManagedConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
ManagedOperation - Annotation Type in org.infinispan.jmx.annotations
Indicates that a method in an MBean class defines an MBean operation.
map - Variable in class org.infinispan.util.concurrent.ConcurrentHashSet
 
MapExternalizer - Class in org.infinispan.marshall.exts
Map externalizer for all map implementations except immutable maps and singleton maps, i.e.
MapExternalizer() - Constructor for class org.infinispan.marshall.exts.MapExternalizer
 
marshal(Configuration.ClusteringType) - Method in class org.infinispan.config.Configuration.ClusteringTypeAdapter
 
marshal(TypedProperties) - Method in class org.infinispan.config.TypedPropertiesAdapter
 
marshall(StreamingMarshaller, Object) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
Marshallable - Annotation Type in org.infinispan.marshall
This annotation is used for those classes that need to be marshalled/unmarshalled between nodes in the cluster or to/from cache stores.
marshallCollection(Collection, ObjectOutput) - Static method in class org.infinispan.marshall.MarshallUtil
 
MARSHALLED_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
MarshalledValue - Class in org.infinispan.marshall
Wrapper that wraps cached data, providing lazy deserialization using the calling thread's context class loader.
MarshalledValue(Object, boolean, StreamingMarshaller) - Constructor for class org.infinispan.marshall.MarshalledValue
 
MarshalledValue(byte[], int, StreamingMarshaller) - Constructor for class org.infinispan.marshall.MarshalledValue
 
MarshalledValue.Externalizer - Class in org.infinispan.marshall
 
MarshalledValue.Externalizer() - Constructor for class org.infinispan.marshall.MarshalledValue.Externalizer
 
MarshalledValueInterceptor - Class in org.infinispan.interceptors
Interceptor that handles the wrapping and unwrapping of cached data using MarshalledValues.
MarshalledValueInterceptor() - Constructor for class org.infinispan.interceptors.MarshalledValueInterceptor
 
marshaller - Variable in class org.infinispan.CacheDelegate
 
MARSHALLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
marshaller - Variable in class org.infinispan.loaders.AbstractCacheLoader
 
marshaller - Variable in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
Marshaller - Interface in org.infinispan.marshall
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
marshaller - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
MarshallerAdapter - Class in org.infinispan.remoting.transport.jgroups
Bridge between JGroups and Infinispan marshallers
MarshallerAdapter(StreamingMarshaller) - Constructor for class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
marshallerClass - Variable in class org.infinispan.config.GlobalConfiguration.SerializationType
 
MarshallerFactory - Class in org.infinispan.factories
MarshallerFactory.
MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
 
marshallMap(Map, ObjectOutput) - Static method in class org.infinispan.marshall.MarshallUtil
 
MarshallUtil - Class in org.infinispan.marshall
MarshallUtil.
MarshallUtil() - Constructor for class org.infinispan.marshall.MarshallUtil
 
max - Variable in class org.infinispan.query.impl.AbstractIterator
 
MAX_BATCH_SIZE - Static variable in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
 
maxEntries - Variable in class org.infinispan.config.Configuration.EvictionType
 
maxIdle - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
maxIdle - Variable in class org.infinispan.config.Configuration.ExpirationType
 
MBean - Annotation Type in org.infinispan.jmx.annotations
Classes annotated with this will be exposed as MBeans.
MBeanAttribute - Class in org.infinispan.tools.doclet.jmx
An MBean attribute
MBeanAttribute() - Constructor for class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
MBeanComponent - Class in org.infinispan.tools.doclet.jmx
* An MBean component
MBeanComponent() - Constructor for class org.infinispan.tools.doclet.jmx.MBeanComponent
 
MBeanOperation - Class in org.infinispan.tools.doclet.jmx
An MBean operation
MBeanOperation() - Constructor for class org.infinispan.tools.doclet.jmx.MBeanOperation
 
mBeanServerLookup - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
MBeanServerLookup - Interface in org.infinispan.jmx
Implementors of this should return an MBeanServer to which MBeans will be registered.
members - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
MembershipArithmetic - Class in org.infinispan.remoting
A helper to perform common arithmetic functions with membership lists
MembershipArithmetic() - Constructor for class org.infinispan.remoting.MembershipArithmetic
 
membersListLock - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
MEMCACHED_CACHE_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
merge(DeltaAware) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
merge(DeltaAware) - Method in interface org.infinispan.atomic.Delta
Merge the current Delta instance with a given DeltaAware instance, and return a coherent and complete DeltaAware instance.
merge(DeltaAware) - Method in enum org.infinispan.atomic.NullDelta
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.infinispan.server.websocket.WebSocketServerHandler
 
metadata - Variable in class org.infinispan.io.GridFilesystem
 
metadataCacheName - Static variable in class org.infinispan.demos.gridfs.CacheManagerHolder
 
method - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
MIME - Static variable in interface org.infinispan.server.websocket.OpHandler
 
MIMECacheEntry - Class in org.infinispan.remoting
Wrapper object for entries that arrive via RESTful PUT/POST interface.
MIMECacheEntry() - Constructor for class org.infinispan.remoting.MIMECacheEntry
 
MIMECacheEntry(String, byte[]) - Constructor for class org.infinispan.remoting.MIMECacheEntry
 
MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get misses.
mkdir() - Method in class org.infinispan.io.GridFile
 
mkdirs() - Method in class org.infinispan.io.GridFile
 
mode - Variable in class org.infinispan.config.Configuration.ClusteringType
 
modelGroup(XSModelGroup) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
modelGroupDecl(XSModelGroupDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
Modification - Interface in org.infinispan.loaders.modifications
An interface that defines a CacheStore modification
Modification.Type - Enum in org.infinispan.loaders.modifications
 
modifications - Variable in class org.infinispan.commands.tx.PrepareCommand
 
ModificationsList - Class in org.infinispan.loaders.modifications
ModificationsList contains a List
ModificationsList(List<? extends Modification>) - Constructor for class org.infinispan.loaders.modifications.ModificationsList
 
ModificationsTransactionWorker - Class in org.infinispan.loaders.bdbje
Adapter that allows a list of Modifications to be performed atomically via TransactionRunner.
ModificationsTransactionWorker(CacheStore, List<? extends Modification>) - Constructor for class org.infinispan.loaders.bdbje.ModificationsTransactionWorker
Associates Modifications that will be applied to the supplied CacheStore
modifiedEntries - Variable in class org.infinispan.util.Util.MapModifications
 
MODULE_CONFIGURATION_CLASS - Static variable in class org.infinispan.util.ModuleProperties
 
MODULE_LIFECYCLE - Static variable in class org.infinispan.util.ModuleProperties
 
MODULE_NAME_KEY - Static variable in class org.infinispan.util.ModuleProperties
 
MODULE_PROPERTIES_FILENAME - Static variable in class org.infinispan.util.ModuleProperties
 
ModuleLifecycle - Interface in org.infinispan.lifecycle
ModuleLifecycle is an internal API hook for delegating lifecycle events to Infinispan sub-modules.
moduleLifecycles - Static variable in class org.infinispan.factories.AbstractComponentRegistry
 
ModuleProperties - Class in org.infinispan.util
The ModuleProperties class represents Infinispan's module configuration key value pairs.
ModuleProperties() - Constructor for class org.infinispan.util.ModuleProperties
 
MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
MORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
MortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is mortal.
MortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
MortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
MortalCacheValue - Class in org.infinispan.container.entries
A mortal cache value, to correspond with MortalCacheEntry
MortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
MortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
move(Fqn, Fqn) - Method in interface org.infinispan.tree.TreeCache
Moves a part of the cache to a different subtree.
move(Fqn, Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
move(String, String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes in string representations of Fqns.
move(String, String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
move(Fqn, Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(Fqn, Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(String, String) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(String, String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
MULTIPLE_RPC_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
multipleKeys() - Method in class org.infinispan.commands.control.LockControlCommand
 
MultipleRpcCommand - Class in org.infinispan.commands.remote
Command that implements cluster replication logic.
MultipleRpcCommand(List<ReplicableCommand>, String) - Constructor for class org.infinispan.commands.remote.MultipleRpcCommand
 
MultipleRpcCommand() - Constructor for class org.infinispan.commands.remote.MultipleRpcCommand
 
multiThreadedPurge - Variable in class org.infinispan.loaders.AbstractCacheStore
 
MurmurHash2 - Class in org.infinispan.util.hash
An implementation of Austin Appleby's MurmurHash2.0 algorithm, as documented on his website.
MurmurHash2() - Constructor for class org.infinispan.util.hash.MurmurHash2
 
MVCCEntry - Interface in org.infinispan.container.entries
An entry that can be safely copied when updates are made, to provide MVCC semantics

N

name - Variable in class org.infinispan.config.Configuration
 
name - Variable in class org.infinispan.tools.doclet.jmx.JmxComponent
 
NamedCacheNotFoundException - Exception in org.infinispan.manager
Thrown when a named cache cannot be found.
NamedCacheNotFoundException(String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedComponentFactory - Class in org.infinispan.factories
A specialized type of component factory that knows how to create named components, identified with the ComponentName annotation on the classes requested in Inject annotated methods.
NamedComponentFactory() - Constructor for class org.infinispan.factories.NamedComponentFactory
 
NamedExecutorsFactory - Class in org.infinispan.factories
A factory that specifically knows how to create named executors.
NamedExecutorsFactory() - Constructor for class org.infinispan.factories.NamedExecutorsFactory
 
NamespaceFilter - Class in org.infinispan.config.parsing
Adds namespace where needed when parsing an XML document
NamespaceFilter() - Constructor for class org.infinispan.config.parsing.NamespaceFilter
 
NaturalComparator - Class in org.infinispan.loaders.jdbm
Compares keys using their natural ordering.
NaturalComparator() - Constructor for class org.infinispan.loaders.jdbm.NaturalComparator
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
needMoreResponses() - Method in interface org.infinispan.remoting.rpc.ResponseFilter
Right after calling ResponseFilter.isAcceptable(Response, Address), this method is called to see whether we are done with the request and can unblock the caller
needMoreResponses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
 
needToDestroyFailedCache() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
needToInitializeBeforeStart() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
newBulkGetOperation(int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newCatchThrowableProxy(Object) - Static method in class org.infinispan.util.Proxies
 
newClearOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newCondition() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
newConsistentHash(int) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
newContainsKeyOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newFixedThreadPool(int, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue.
newFixedThreadPool(int, ThreadFactory, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue, using the provided ThreadFactory to create new threads when needed.
newGetKeyOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGetWithVersionOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGlobalTransaction(Address, boolean) - Method in class org.infinispan.transaction.xa.GlobalTransactionFactory
 
newInfinispanConfiguration(String, String) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(String, String, ConfigurationBeanVisitor) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(String) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(InputStream) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(Reader) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(InputStream, InputStream) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(Reader, InputStream) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(Reader, InputStream, ConfigurationBeanVisitor) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(InputStream, InputStream, ConfigurationBeanVisitor) - Static method in class org.infinispan.config.InfinispanConfiguration
Factory method to create an instance of Infinispan configuration.
newInstance(Cache, Object) - Static method in class org.infinispan.atomic.AtomicHashMap
Construction only allowed through this factory method.
newKeyAffinityService(Cache<K, V>, Executor, KeyGenerator, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Creates an KeyAffinityService instance that generates keys mapped to all addresses in the cluster.
newKeyAffinityService(Cache<K, V>, Executor, KeyGenerator, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.concurrent.Executor, KeyGenerator, int, boolean) with start == true;
newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator, Executor, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Creates a service that would only generate keys for addresses specified in filter.
newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.Collection, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
newLocalKeyAffinityService(Cache<K, V>, KeyGenerator, Executor, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Created an service that only generates keys for the local address.
newLocalKeyAffinityService(Cache<K, V>, KeyGenerator, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Same as KeyAffinityServiceFactory.newLocalKeyAffinityService(org.infinispan.Cache, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
newPutIfAbsentOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newPutKeyValueOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newRemoveIfUnmodifiedOperation(byte[], long) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newRemoveOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newReplaceIfUnmodifiedOperation(byte[], byte[], int, int, long) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newReplaceOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newStatsOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
next() - Method in class org.infinispan.query.impl.EagerIterator
Returns the next element in the list
next() - Method in class org.infinispan.query.impl.LazyIterator
 
nextIndex() - Method in class org.infinispan.query.impl.EagerIterator
Returns the index of the element that would be returned by a subsequent call to next.
nextIndex() - Method in class org.infinispan.query.impl.LazyIterator
 
nextServer() - Method in interface org.infinispan.client.hotrod.impl.transport.tcp.RequestBalancingStrategy
 
nextServer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
Multiple threads might call this method at the same time.
NO_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
Node<K,V> - Interface in org.infinispan.tree
A Node is a named logical grouping of data in the TreeCache API of JBoss Cache.
NODE_KEY - Static variable in interface org.infinispan.marshall.Ids
ids for infinispan tree classes *
NodeImpl<K,V> - Class in org.infinispan.tree
Implementation backed by an AtomicMap
NodeImpl(Fqn, Cache<?, ?>, BatchContainer, InvocationContextContainer) - Constructor for class org.infinispan.tree.NodeImpl
 
NodeKey - Class in org.infinispan.tree
A class that represents the key to a node
NodeKey(Fqn, NodeKey.Type) - Constructor for class org.infinispan.tree.NodeKey
 
NodeKey.Externalizer - Class in org.infinispan.tree
 
NodeKey.Externalizer() - Constructor for class org.infinispan.tree.NodeKey.Externalizer
 
NodeKey.Type - Enum in org.infinispan.tree
 
nodeName - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
 
NodeNotExistsException - Exception in org.infinispan.tree
Thrown when an operation is attempted on a non-existing node in the cache
NodeNotExistsException() - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotExistsException(String) - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotExistsException(String, Throwable) - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotValidException - Exception in org.infinispan.tree
Thrown whenever operations are attempted on a node that is no longer valid.
NodeNotValidException() - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(Throwable) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(String) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(String, Throwable) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NonTxInvocationContext - Class in org.infinispan.context.impl
Context to be used for non transactional calls, both remote and local.
NonTxInvocationContext() - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NoopSegmentReadLocker - Class in org.infinispan.lucene.readlocks
NoopSegmentReadLocker ignores requests to apply a readlock, but also ignores requests to delete files.
NoopSegmentReadLocker() - Constructor for class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
 
NoState - Enum in org.infinispan.server.core.transport
A simple enumeration marker that signals the lack of state choices.
NOT_PUT_REMOVED_REPLACED_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
notation(XSNotation) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
NotificationInterceptor - Class in org.infinispan.interceptors
The interceptor in charge of firing off notifications to cache listeners
NotificationInterceptor() - Constructor for class org.infinispan.interceptors.NotificationInterceptor
 
notifier - Variable in class org.infinispan.CacheDelegate
 
notifier - Variable in class org.infinispan.commands.tx.PrepareCommand
 
notifier - Variable in class org.infinispan.commands.write.RemoveCommand
 
notifier - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
notifier - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.EvictCommand
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.InvalidateCommand
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.RemoveCommand
 
notifyAfterCompletion(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
notifyBeforeCompletion() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
notifyCacheEntryActivated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryActivated event.
notifyCacheEntryActivated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryCreated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryCreated event.
notifyCacheEntryCreated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryEvicted(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryEvicted event.
notifyCacheEntryEvicted(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryInvalidated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryInvalidated event.
notifyCacheEntryInvalidated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryLoaded(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryLoaded event.
notifyCacheEntryLoaded(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryModified(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryModified event.
notifyCacheEntryModified(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryPassivated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryPassivated event.
notifyCacheEntryPassivated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryRemoved(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryRemoved event.
notifyCacheEntryRemoved(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryVisited(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryVisited event.
notifyCacheEntryVisited(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheStarted(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyCacheStarted(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyCacheStopped(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyCacheStopped(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
notifyDone() - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
notifyFutureCompletion() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
NotifyHandler - Class in org.infinispan.server.websocket.handlers
Handler for the "notify" and "unnotify" operations.
NotifyHandler() - Constructor for class org.infinispan.server.websocket.handlers.NotifyHandler
 
NotifyingFuture<T> - Interface in org.infinispan.util.concurrent
A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified of when the future completes.
NotifyingFutureImpl<T> - Class in org.infinispan.client.hotrod.impl.async
Notifying future implementation for async calls.
NotifyingFutureImpl() - Constructor for class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
NotifyingFutureImpl - Class in org.infinispan.util.concurrent
Constructs an instance of a NotifyingFuture.
NotifyingFutureImpl(Object) - Constructor for class org.infinispan.util.concurrent.NotifyingFutureImpl
 
NotifyingNotifiableFuture<Object> - Interface in org.infinispan.util.concurrent
An internal interface which adds the ability to inform the future of completion.
notifyJoinComplete(Address) - Method in interface org.infinispan.distribution.DistributionManager
Notifies a coordinator when a join completes
notifyJoinComplete(Address) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
notifyStateReceiptFailed(StateTransferException) - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
notifyStateReceiptSucceeded() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction completion event.
notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyTransactionRegistered(GlobalTransaction, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction registration event.
notifyTransactionRegistered(GlobalTransaction, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyViewChange(List<Address>, List<Address>, Address, int, boolean) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
Notifies all registered listeners of a viewChange event.
notifyViewChange(List<Address>, List<Address>, Address, int, boolean) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
NotSerializableException - Exception in org.infinispan.marshall
An exception that hides inner stacktrace lines for non serializable exceptions.
NotSerializableException(String, Throwable) - Constructor for exception org.infinispan.marshall.NotSerializableException
 
Nucleotide_Protein_Element - Class in org.infinispan.ec2demo
 
Nucleotide_Protein_Element() - Constructor for class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
Nucleotide_Protein_Parser - Class in org.infinispan.ec2demo
 
Nucleotide_Protein_Parser() - Constructor for class org.infinispan.ec2demo.Nucleotide_Protein_Parser
 
NucleotideCache - Class in org.infinispan.ec2demo
 
NucleotideCache(CacheBuilder) - Constructor for class org.infinispan.ec2demo.NucleotideCache
 
NULL_COMPONENT - Static variable in class org.infinispan.factories.AbstractComponentRegistry
 
NullDelta - Enum in org.infinispan.atomic
Represents no changes.
NullMarkerEntry - Class in org.infinispan.container.entries
A marker entry to represent a null for repeatable read, so that a read that returns a null can continue to return null.
NullMarkerEntryForRemoval - Class in org.infinispan.container.entries
A null entry that is read in for removal
NullMarkerEntryForRemoval(Object) - Constructor for class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
numOwners - Variable in class org.infinispan.config.Configuration.HashType
 
numRetries - Variable in class org.infinispan.config.Configuration.StateRetrievalType
 

O

OBJECT_NAME - Static variable in class org.infinispan.CacheDelegate
 
OBJECT_NAME - Static variable in class org.infinispan.manager.DefaultCacheManager
 
ObjectDuplicator - Class in org.infinispan.util
A helper that efficiently duplicates known object types.
ObjectDuplicator() - Constructor for class org.infinispan.util.ObjectDuplicator
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
objectFromByteBuffer(byte[]) - Method in interface org.infinispan.marshall.Marshaller
Unmarshalls an object from a byte array.
objectFromByteBuffer(byte[], int, int) - Method in interface org.infinispan.marshall.Marshaller
Unmarshalls an object from a specific portion of a byte array.
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.AbstractStreamingMarshaller
 
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
objectFromInputStream(InputStream) - Method in interface org.infinispan.marshall.StreamingMarshaller
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Unmarshalls an object from an ObjectInput
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.AbstractMarshaller
This is a convenience method for converting an object into a ByteBuffer which takes an estimated size as parameter.
objectToBuffer(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
objectToBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
A method that returns an instance of ByteBuffer, which allows direct access to the byte array with minimal array copying
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, int) - Method in interface org.infinispan.marshall.Marshaller
Marshalls an object to a byte array.
objectToByteBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
Marshalls an object to a byte array.
objectToByteBuffer(Object) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Marshalls an object to a given ObjectOutput
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
oldValue - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
onEntryHit(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that an entry in Segment has been accessed.
onEntryMiss(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that there has been an attempt to access an entry in Segment, however that entry was not present in Segment.
onEntryRemove(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that an entry e has been removed from Segment.
onePhaseCommit - Variable in class org.infinispan.commands.tx.PrepareCommand
 
onRehash - Variable in class org.infinispan.config.Configuration.L1Type
 
onViewChange(ViewChangedEvent) - Method in class org.infinispan.transaction.xa.TransactionTable.StaleTransactionCleanup
 
OP_CODE - Static variable in interface org.infinispan.server.websocket.OpHandler
 
open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
openInput(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Operation<K,V> - Class in org.infinispan.atomic
An atomic operation.
Operation() - Constructor for class org.infinispan.atomic.Operation
 
operations - Variable in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
OperationsFactory - Class in org.infinispan.client.hotrod.impl.operations
Factory for HotRodOperation objects.
OperationsFactory(TransportFactory, String, AtomicInteger, boolean) - Constructor for class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
OpHandler - Interface in org.infinispan.server.websocket
Websocket cache operation handler.
optionLength(String) - Static method in class org.infinispan.tools.doclet.config.ConfigDoclet
 
optionLength(String) - Static method in class org.infinispan.tools.doclet.jmx.JmxDoclet
 
org.infinispan - package org.infinispan
This is the core of Infinispan, a distributed, transactional, highly scalable data grid platform.
org.infinispan.affinity - package org.infinispan.affinity
 
org.infinispan.atomic - package org.infinispan.atomic
This package contains the AtomicMap interfaces and API that Infinispan exposes as building blocks in creating other public interfaces such as the Tree API.
org.infinispan.batch - package org.infinispan.batch
Support for batching calls using the Cache.startBatch() and Cache.endBatch(boolean) API.
org.infinispan.client.hotrod - package org.infinispan.client.hotrod
 
org.infinispan.client.hotrod.exceptions - package org.infinispan.client.hotrod.exceptions
 
org.infinispan.client.hotrod.impl - package org.infinispan.client.hotrod.impl
 
org.infinispan.client.hotrod.impl.async - package org.infinispan.client.hotrod.impl.async
 
org.infinispan.client.hotrod.impl.consistenthash - package org.infinispan.client.hotrod.impl.consistenthash
 
org.infinispan.client.hotrod.impl.operations - package org.infinispan.client.hotrod.impl.operations
 
org.infinispan.client.hotrod.impl.protocol - package org.infinispan.client.hotrod.impl.protocol
 
org.infinispan.client.hotrod.impl.transport - package org.infinispan.client.hotrod.impl.transport
 
org.infinispan.client.hotrod.impl.transport.tcp - package org.infinispan.client.hotrod.impl.transport.tcp
 
org.infinispan.commands - package org.infinispan.commands
Commands that operate on the cache, either locally or remotely.
org.infinispan.commands.control - package org.infinispan.commands.control
Commands that control and coordinate certain cache operations, such as rehashing, state transfer and locking.
org.infinispan.commands.read - package org.infinispan.commands.read
Commands that read data from the cache.
org.infinispan.commands.remote - package org.infinispan.commands.remote
Meta-commands that wrap other commands for remote execution.
org.infinispan.commands.tx - package org.infinispan.commands.tx
Commands that represent transactional lifecycle transitions.
org.infinispan.commands.write - package org.infinispan.commands.write
Commands that alter the state of the cache.
org.infinispan.config - package org.infinispan.config
Cache configuration beans and parsers.
org.infinispan.config.parsing - package org.infinispan.config.parsing
 
org.infinispan.container - package org.infinispan.container
Data containers which store cache entries.
org.infinispan.container.entries - package org.infinispan.container.entries
Entries which are stored in data containers.
org.infinispan.context - package org.infinispan.context
Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags.
org.infinispan.context.impl - package org.infinispan.context.impl
This package contains different context implementations, selected dynamically based on the type of invocation.
org.infinispan.demo - package org.infinispan.demo
Classes, programs and applications that help demonstrate how Infinispan can be used.
org.infinispan.demos.directory - package org.infinispan.demos.directory
 
org.infinispan.demos.gridfs - package org.infinispan.demos.gridfs
 
org.infinispan.distribution - package org.infinispan.distribution
Classes relating to the distributed cache mode.
org.infinispan.ec2demo - package org.infinispan.ec2demo
 
org.infinispan.ec2demo.web - package org.infinispan.ec2demo.web
 
org.infinispan.eviction - package org.infinispan.eviction
Classes related to eviction.
org.infinispan.executors - package org.infinispan.executors
Implementations of different executors used for asynchronous operation.
org.infinispan.factories - package org.infinispan.factories
Factories are internal components used to create other components based on a cache's configuration.
org.infinispan.factories.annotations - package org.infinispan.factories.annotations
Internal annotations to control the lifecycle of cache components.
org.infinispan.factories.scopes - package org.infinispan.factories.scopes
Scopes of components within the lifespan of a CacheManager and its various Caches, and related utilities.
org.infinispan.interceptors - package org.infinispan.interceptors
Infinispan is designed around a set of interceptors around a data container.
org.infinispan.interceptors.base - package org.infinispan.interceptors.base
Base interceptors containing common, reusable behavior.
org.infinispan.io - package org.infinispan.io
Provides Infinispan-specific input and output streams, buffers and related utilities.
org.infinispan.jmx - package org.infinispan.jmx
Helpers that allow easy exposure of attributes and operations via JMX.
org.infinispan.jmx.annotations - package org.infinispan.jmx.annotations
JMX 2.0-like annotations, with no dependencies on JMX 2.0.
org.infinispan.jopr - package org.infinispan.jopr
 
org.infinispan.lifecycle - package org.infinispan.lifecycle
Component lifecycle.
org.infinispan.loaders - package org.infinispan.loaders
This package contains loaders and stores, which are used for overflow or persistence.
org.infinispan.loaders.bdbje - package org.infinispan.loaders.bdbje
This package contains a CacheStore implementation based on Oracle's BDBJE storage engine.
org.infinispan.loaders.bucket - package org.infinispan.loaders.bucket
Abstract classes that use hashed buckets to store entries.
org.infinispan.loaders.cloud - package org.infinispan.loaders.cloud
This package contains a CacheStore implementation based on JClouds, which in turn is an abstraction layer to store data on cloud infrastructure providers such as Amazon's S3, RackspaceCloud's CloudFiles, Microsoft's Windows Azure Blob Storage API, and others.
org.infinispan.loaders.cluster - package org.infinispan.loaders.cluster
A CacheLoader (not CacheStore) that polls other nodes in the cluster for state.
org.infinispan.loaders.decorators - package org.infinispan.loaders.decorators
This package contains loaders and stores, which are used for overflow or persistence.
org.infinispan.loaders.file - package org.infinispan.loaders.file
Simple filesystem-based CacheStore implementation.
org.infinispan.loaders.jdbc - package org.infinispan.loaders.jdbc
This package contains a CacheStore implementation based on a JDBC database connection.
org.infinispan.loaders.jdbc.binary - package org.infinispan.loaders.jdbc.binary
This JDBC CacheStore implementation is optimized for storing binary (non-String) keys in the cache.
org.infinispan.loaders.jdbc.connectionfactory - package org.infinispan.loaders.jdbc.connectionfactory
Connection factories for use with the JDBC Cache Store.
org.infinispan.loaders.jdbc.mixed - package org.infinispan.loaders.jdbc.mixed
This is a delegating CacheStore implementation that delegates either to a binary or String based JDBC cache store depending on the key used.
org.infinispan.loaders.jdbc.stringbased - package org.infinispan.loaders.jdbc.stringbased
This JDBC CacheStore implementation is optimized for storing String keys in the cache.
org.infinispan.loaders.jdbm - package org.infinispan.loaders.jdbm
This package contains a CacheStore implementation based on persisting to JDBM.
org.infinispan.loaders.modifications - package org.infinispan.loaders.modifications
Modifications that are used to encapsulate cache operations for application to a CacheStore.
org.infinispan.loaders.remote - package org.infinispan.loaders.remote
 
org.infinispan.lucene - package org.infinispan.lucene
Lucene Directory implementation which stores the index in Infinispan.
org.infinispan.lucene.locking - package org.infinispan.lucene.locking
Lucene's IndexWriter instances are threadsafe but you can have only one open on the index, so when opening an IndexWriter an index-wide lock needs to be acquired.
org.infinispan.lucene.readlocks - package org.infinispan.lucene.readlocks
Several implementations for a SegmentReadLocker, pick one depending on your use case.
org.infinispan.lucenedemo - package org.infinispan.lucenedemo
 
org.infinispan.manager - package org.infinispan.manager
Cache manager package
org.infinispan.marshall - package org.infinispan.marshall
Infinispan makes use of custom marshalling to serialize and deserialize state wherever possible, rather than falling back to the JDK to do this.
org.infinispan.marshall.exts - package org.infinispan.marshall.exts
Externalizers for various JDK types that are marshalled using the marshalling framework.
org.infinispan.marshall.jboss - package org.infinispan.marshall.jboss
Hooks to bridge Infinispan's marshalling APIs with JBoss Marshalling internals.
org.infinispan.notifications - package org.infinispan.notifications
Notifications and eventing for listeners on both the Cache and CacheManager interfaces.
org.infinispan.notifications.cachelistener - package org.infinispan.notifications.cachelistener
Cache-specific notifications and eventing.
org.infinispan.notifications.cachelistener.annotation - package org.infinispan.notifications.cachelistener.annotation
 
org.infinispan.notifications.cachelistener.event - package org.infinispan.notifications.cachelistener.event
 
org.infinispan.notifications.cachemanagerlistener - package org.infinispan.notifications.cachemanagerlistener
CacheManager-specific notifications and eventing.
org.infinispan.notifications.cachemanagerlistener.annotation - package org.infinispan.notifications.cachemanagerlistener.annotation
 
org.infinispan.notifications.cachemanagerlistener.event - package org.infinispan.notifications.cachemanagerlistener.event
 
org.infinispan.query - package org.infinispan.query
 
org.infinispan.query.backend - package org.infinispan.query.backend
 
org.infinispan.query.impl - package org.infinispan.query.impl
 
org.infinispan.remoting - package org.infinispan.remoting
Remote communication between cache instances.
org.infinispan.remoting.responses - package org.infinispan.remoting.responses
Abstractions of the different response types allowed during RPC.
org.infinispan.remoting.rpc - package org.infinispan.remoting.rpc
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
org.infinispan.remoting.transport - package org.infinispan.remoting.transport
Transports handle the low-level networking, used by the remoting components.
org.infinispan.remoting.transport.jgroups - package org.infinispan.remoting.transport.jgroups
A transport implementation based on JGroups.
org.infinispan.server.core.transport - package org.infinispan.server.core.transport
 
org.infinispan.server.websocket - package org.infinispan.server.websocket
 
org.infinispan.server.websocket.handlers - package org.infinispan.server.websocket.handlers
 
org.infinispan.statetransfer - package org.infinispan.statetransfer
Transfer of state to new caches in a cluster.
org.infinispan.stats - package org.infinispan.stats
Cache statistics.
org.infinispan.tools - package org.infinispan.tools
 
org.infinispan.tools.doclet.config - package org.infinispan.tools.doclet.config
 
org.infinispan.tools.doclet.html - package org.infinispan.tools.doclet.html
 
org.infinispan.tools.doclet.jmx - package org.infinispan.tools.doclet.jmx
 
org.infinispan.tools.jopr - package org.infinispan.tools.jopr
 
org.infinispan.tools.schema - package org.infinispan.tools.schema
 
org.infinispan.transaction - package org.infinispan.transaction
JTA transaction support.
org.infinispan.transaction.lookup - package org.infinispan.transaction.lookup
Interfaces and implementations of lookup classes to locate and/or instantiate JTA TransactionManagers.
org.infinispan.transaction.tm - package org.infinispan.transaction.tm
Infinispan's bare-bones internal transaction manager, used for batching calls as well as as a dummy, unit-test-only transaction manager.
org.infinispan.transaction.xa - package org.infinispan.transaction.xa
XA transaction support.
org.infinispan.tree - package org.infinispan.tree
This package contains the TreeCache.
org.infinispan.util - package org.infinispan.util
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and collections and containers designed to supplement the JDK-provided containers.
org.infinispan.util.concurrent - package org.infinispan.util.concurrent
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities and containers.
org.infinispan.util.concurrent.locks - package org.infinispan.util.concurrent.locks
Lock and synchronization related classes, tools and utilities.
org.infinispan.util.concurrent.locks.containers - package org.infinispan.util.concurrent.locks.containers
Concurrent lock containers.
org.infinispan.util.hash - package org.infinispan.util.hash
 
org.infinispan.util.logging - package org.infinispan.util.logging
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
overriddenConfigurationElements - Variable in class org.infinispan.config.AbstractConfigurationBean
 
override(OverrideConfigurationVisitor) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
OverrideConfigurationVisitor - Class in org.infinispan.config
OverrideConfigurationVisitor breaks down fields of Configuration object to individual components and then compares them for field updates.
OverrideConfigurationVisitor() - Constructor for class org.infinispan.config.OverrideConfigurationVisitor
 
OwnableReentrantLock - Class in org.infinispan.util.concurrent.locks
A lock that supports reentrancy based on owner (and not on current thread).
OwnableReentrantLock(InvocationContextContainer) - Constructor for class org.infinispan.util.concurrent.locks.OwnableReentrantLock
Creates a new lock instance.
OwnableReentrantPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A per-entry lock container for OwnableReentrantLocks
OwnableReentrantPerEntryLockContainer(int, InvocationContextContainer) - Constructor for class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
OwnableReentrantStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A LockContainer that holds OwnableReentrantLocks.
OwnableReentrantStripedLockContainer(int, InvocationContextContainer) - Constructor for class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
Creates a new LockContainer which uses a certain number of shared locks across all elements that need to be locked.
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
Tests if a give owner owns a lock on a specified object.
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Tests whether a given owner owns a lock of lockType on a particular cache entry.
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 

P

padString(String, int) - Static method in class org.infinispan.util.Util
 
parse(InputStream, OutputStream, String) - Method in class org.infinispan.config.parsing.ConfigFilesConvertor
 
parse(String, OutputStream, String) - Method in class org.infinispan.config.parsing.ConfigFilesConvertor
Writes to the os the infinispan 4.x configuration file resulted by transforming configuration file passed in as inputFile.
parseClusterConfigXml(Element) - Method in class org.infinispan.config.parsing.JGroupsStackParser
Parses the cluster config which is used to start a JGroups channel
parseDefaultConfiguration() - Method in class org.infinispan.config.InfinispanConfiguration
 
parseDefaultConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses the default template configuration.
parseFile(String) - Method in class org.infinispan.ec2demo.Influenza_Parser
 
parseFile(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Parser
 
parseGlobalConfiguration() - Method in class org.infinispan.config.InfinispanConfiguration
 
parseGlobalConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
GlobalConfiguration would also have a reference to the template default configuration, accessible via org.infinispan.config.GlobalConfiguration#getDefaultConfiguration()

This is typically used to configure a DefaultCacheManager

parseNamedConfigurations() - Method in class org.infinispan.config.InfinispanConfiguration
 
parseNamedConfigurations() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses and retrieves configuration overrides for named caches.
parseQuery(String) - Method in class org.infinispan.lucenedemo.DemoActions
Parses a query using the single field as default
parseTag(String) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
particle(XSParticle) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
passivate(Object, InternalCacheEntry, InvocationContext) - Method in interface org.infinispan.eviction.PassivationManager
 
passivate(Object, InternalCacheEntry, InvocationContext) - Method in class org.infinispan.eviction.PassivationManagerImpl
 
passivateObject(Object, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
passivation - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
PassivationInterceptor - Class in org.infinispan.interceptors
Writes evicted entries back to the store on the way in through the CacheStore
PassivationInterceptor() - Constructor for class org.infinispan.interceptors.PassivationInterceptor
 
PassivationManager - Interface in org.infinispan.eviction
A passivation manager
PassivationManagerImpl - Class in org.infinispan.eviction
 
PassivationManagerImpl() - Constructor for class org.infinispan.eviction.PassivationManagerImpl
 
PATH - Static variable in class org.infinispan.util.ClassFinder
 
peek(Object) - Method in interface org.infinispan.container.DataContainer
Retrieves a cache entry in the same way as DataContainer.get(Object)} except that it does not update or reorder any of the internal constructs.
peek(Object) - Method in class org.infinispan.container.DefaultDataContainer
 
peekElements() - Method in class org.infinispan.tree.Fqn
Peeks into the elements that build up this Fqn.
perform(InvocationContext) - Method in class org.infinispan.commands.control.LockControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.control.RehashControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.EntrySetCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.KeySetCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.SizeCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.ValuesCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
Invokes a logical "get(key)" on a remote cache and returns results.
perform(InvocationContext) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
Executes commands replicated to the current cache instance by other cache instances.
perform(InvocationContext) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
perform(InvocationContext) - Method in interface org.infinispan.commands.ReplicableCommand
Performs the primary function of the command.
perform(InvocationContext) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.tx.PrepareCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ClearCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.EvictCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateCommand
Performs an invalidation on a specified entry
perform(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.PutMapCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.RemoveCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ReplaceCommand
 
performRehash() - Method in class org.infinispan.distribution.InvertedLeaveTask
 
performRehash() - Method in class org.infinispan.distribution.JoinTask
 
performRehash() - Method in class org.infinispan.distribution.RehashTask
 
physicalAddress - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
PING_ON_STARTUP - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PING_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PING_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PingOperation - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to the "ping" operation as defined in Hot Rod protocol specification.
PingOperation(Flag[], AtomicInteger, Transport) - Constructor for class org.infinispan.client.hotrod.impl.operations.PingOperation
 
PlatformMBeanServerLookup - Class in org.infinispan.jmx
Default implementation for MBeanServerLookup, will return the platform MBean server.
PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
 
PluggableConfigurationComponent - Class in org.infinispan.config
A configuration component where the implementation class can be specified, and comes with its own set of properties.
PluggableConfigurationComponent() - Constructor for class org.infinispan.config.PluggableConfigurationComponent
 
PooledConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Pooled connection factory based on C3P0.
PooledConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
populateCache(JSAPResult) - Method in class org.infinispan.ec2demo.InfluenzaDataLoader
 
position - Variable in class org.infinispan.config.CustomInterceptorConfig
 
possiblyLocked(CacheEntry) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Inspects the entry for signs that it is possibly locked, and hence would need to be unlocked.
possiblyLocked(CacheEntry) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
postEvict(Object, InternalCacheEntry) - Method in interface org.infinispan.eviction.EvictionManager
 
postEvict(Object, InternalCacheEntry) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
postEvict(K, V) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionListener
 
postOrderTraverse(TreeNode) - Method in class org.infinispan.tools.schema.AbstractTreeWalker
 
postVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Callback invoked after visiting the specified node n.
postVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
postXMLTableOfContentsCreate(XSOMSchemaTreeWalker, XMLTreeOutputWalker) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Invoked after creation of XML tree table of contents for configuration elements in schema
preEvict(Object) - Method in interface org.infinispan.eviction.EvictionManager
 
preEvict(Object) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
preEvict(K) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionListener
 
preload - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
preload() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
preload() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
Performs a preload on the cache based on the cache loader preload configs used when configuring the cache.
preOrderTraverse(TreeNode) - Method in class org.infinispan.tools.schema.AbstractTreeWalker
 
PreparableTransactionRunner - Class in org.infinispan.loaders.bdbje
Adapted version of TransactionRunner, which allows us to prepare a transaction without committing it.

The transaction prepared is accessible via CurrentTransaction.getTransaction()

PreparableTransactionRunner(Environment, int, TransactionConfig) - Constructor for class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Delegates to the superclass and caches a current reference to CurrentTransaction.
PreparableTransactionRunner(Environment) - Constructor for class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Delegates to the superclass and caches a current reference to CurrentTransaction.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.AbstractCacheStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Issues a prepare call with a set of modifications to be applied to the cache store
prepare(List<? extends Modification>, GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Looks up the SleepyCat transaction associated with tx.
prepare(TransactionWorker) - Method in class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Same behaviour as run, except that the transaction is not committed on success.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in interface org.infinispan.loaders.CacheStore
Issues a prepare call with a set of modifications to be applied to the cache store
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
Prepare - Class in org.infinispan.loaders.modifications
Prepare.
Prepare(List<? extends Modification>, GlobalTransaction, boolean) - Constructor for class org.infinispan.loaders.modifications.Prepare
 
prepare(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
PREPARE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
PrepareCommand - Class in org.infinispan.commands.tx
Command corresponding to the 1st phase of 2PC.
PrepareCommand(GlobalTransaction, boolean, WriteCommand...) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand() - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
prepareRenderer(TableCellRenderer, int, int) - Method in class org.infinispan.demo.InfinispanDemo.AlternateColorTable
Shades alternate rows in different colors.
PrePostProcessingCommandInterceptor - Class in org.infinispan.interceptors.base
This interceptor adds pre and post processing to each visitXXX() method.
PrePostProcessingCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
prettyPrintTime(long, TimeUnit) - Static method in class org.infinispan.util.Util
 
prettyPrintTime(long) - Static method in class org.infinispan.util.Util
Prints a time for display
previous() - Method in class org.infinispan.query.impl.EagerIterator
Returns the previous element in the list.
previous() - Method in class org.infinispan.query.impl.LazyIterator
 
previousIndex() - Method in class org.infinispan.query.impl.EagerIterator
Returns the index of the element that would be returned by a subsequent call to previous.
previousIndex() - Method in class org.infinispan.query.impl.LazyIterator
 
preVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Callback invoked prior to visiting the specified node n.
preVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
preXMLTableOfContentsCreate(XSOMSchemaTreeWalker, XMLTreeOutputWalker) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Invoked prior to creation of XML tree table of contents for configuration elements in schema
preXMLTableOfContentsCreate(XSOMSchemaTreeWalker, XMLTreeOutputWalker) - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
printArray(byte[], boolean) - Static method in class org.infinispan.util.Util
 
printDebugStats() - Method in class org.infinispan.util.FastCopyHashMap
 
printFullVersionInformation() - Static method in class org.infinispan.Version
Prints full version information to the standard output.
printLicense() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
prints terms of use for Berkeley DB JE
printLockInfo() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Prints lock information for all locks.
printLockInfo() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
printTree(TreeCache<?, ?>, boolean) - Static method in class org.infinispan.tree.TreeStructureSupport
Visual representation of a tree
printVersion() - Static method in class org.infinispan.Version
Returns version information as a string.
printVersionId(byte[], int) - Static method in class org.infinispan.Version
 
printVersionId(byte[]) - Static method in class org.infinispan.Version
 
processEviction() - Method in interface org.infinispan.eviction.EvictionManager
Processes the eviction event queue.
processEviction() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
processFile(String, ProteinCache) - Method in class org.infinispan.ec2demo.Influenza_Parser
 
processFile(String, ProteinCache) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Parser
 
processVisitableCommand(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
projectName - Static variable in class org.infinispan.Version
 
properties - Variable in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
 
properties - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
 
properties - Variable in class org.infinispan.config.PluggableConfigurationComponent
 
props - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
PropsKeyedObjectPoolFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
PropsKeyedObjectPoolFactory(KeyedPoolableObjectFactory, Properties) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.PropsKeyedObjectPoolFactory
 
ProteinCache - Class in org.infinispan.ec2demo
 
ProteinCache(CacheBuilder) - Constructor for class org.infinispan.ec2demo.ProteinCache
 
Proxies - Class in org.infinispan.util
Proxies is a collection of useful dynamic profixes.
Proxies() - Constructor for class org.infinispan.util.Proxies
 
pullStateForJoin() - Method in class org.infinispan.commands.control.RehashControlCommand
 
pullStateForLeave() - Method in class org.infinispan.commands.control.RehashControlCommand
 
purge() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
purge() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
purgeExpired() - Method in interface org.infinispan.container.DataContainer
Purges entries that have passed their expiry time
purgeExpired() - Method in class org.infinispan.container.DefaultDataContainer
 
purgeExpired() - Method in class org.infinispan.loaders.AbstractCacheStore
 
purgeExpired() - Method in interface org.infinispan.loaders.CacheStore
Purges expired entries from the store.
purgeExpired() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
PurgeExpired - Class in org.infinispan.loaders.modifications
 
PurgeExpired() - Constructor for class org.infinispan.loaders.modifications.PurgeExpired
 
purgeIfNecessary() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.AbstractCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Iterate through StoredMap.entrySet() and remove, if expired.
purgeInternal() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.file.FileCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Purge expired entries.
purgeInternal() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
purgeOnStartup - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
purgerService - Variable in class org.infinispan.loaders.AbstractCacheStore
 
purgerThreads - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
purgeSynchronously - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
pushCacheValue(String, Cache<Object, Object>, ChannelHandlerContext) - Static method in class org.infinispan.server.websocket.ChannelUtils
Push a cache entry value out onto the websocket channel (to the browser).
pushState() - Method in class org.infinispan.commands.control.RehashControlCommand
 
pushState(Cache) - Method in class org.infinispan.loaders.decorators.SingletonStore
Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
pushStateTimeout - Variable in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
pushStateWhenCoordinator - Variable in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V) - Method in class org.infinispan.atomic.AtomicHashMap
 
put(K, V) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
put(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.put(Object, Object), which takes in lifespan parameters.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.put(Object, Object), which takes in lifespan parameters.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
put(K, V) - Method in class org.infinispan.CacheSupport
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
put(byte[], byte[], int, int, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
put(Object, Object, long, long) - Method in interface org.infinispan.container.DataContainer
Puts an entry in the cache along with a lifespan and a maxIdle time
put(Object, Object, long, long) - Method in class org.infinispan.container.DefaultDataContainer
 
put(K, V) - Method in interface org.infinispan.tree.Node
Associates the specified value with the specified key for this node.
put(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
put(K, V) - Method in class org.infinispan.tree.NodeImpl
 
put(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
put(Fqn, K, V) - Method in interface org.infinispan.tree.TreeCache
Associates the specified value with the specified key for a Node in this cache.
put(Fqn, K, V, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, K, V) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
put(String, K, V, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(Fqn, Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.TreeCache
Copies all of the mappings from the specified map to a Node.
put(Fqn, Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
put(String, Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, K, V) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, K, V, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, K, V) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, K, V, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(K, V) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Associates the specified value with the specified key in this map.
put(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Maps the specified key to the specified value in this table.
put(K, V) - Method in class org.infinispan.util.FastCopyHashMap
 
PUT_IF_ABSENT_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_IF_ABSENT_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_KEY_VALUE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
PUT_MAP_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
PUT_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.AtomicHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.putAll(Map), which takes in lifespan parameters.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of Map.putAll(Map), which takes in lifespan parameters.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.Node
Copies all of the mappings from the specified map to this node's map.
putAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.Node
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.NodeImpl
 
putAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Copies all of the mappings from the specified map to this map.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.FastCopyHashMap
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.Cache
Asynchronous version of Map.putAll(Map).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putAll(Map, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putAll(Map, long, TimeUnit, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V) - Method in interface org.infinispan.Cache
Asynchronous version of Map.put(Object, Object).
putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.put(Object, Object, long, TimeUnit) .
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.put(Object, Object, long, TimeUnit, long, TimeUnit).
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putAsync(K, V) - Method in class org.infinispan.CacheSupport
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putForExternalRead(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putForExternalRead(K, V) - Method in interface org.infinispan.Cache
Under special operating behavior, associates the value with the specified key.
putForExternalRead(K, V) - Method in class org.infinispan.CacheDelegate
 
putForExternalRead(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putForExternalRead(K, V) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
PutHandler - Class in org.infinispan.server.websocket.handlers
Cache "get" operation handler.
PutHandler() - Constructor for class org.infinispan.server.websocket.handlers.PutHandler
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putIfAbsent(K, V) - Method in class org.infinispan.CacheSupport
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putIfAbsent(byte[], byte[], int, int, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putIfAbsent(K, V) - Method in interface org.infinispan.tree.Node
If the specified key is not already associated with a value, associate it with the given value, and returns the Object (if any) that occupied the space, or null.
putIfAbsent(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
putIfAbsent(K, V) - Method in class org.infinispan.tree.NodeImpl
 
putIfAbsent(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
putIfAbsentAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.putIfAbsent(Object, Object).
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putIfAbsent(Object, Object, long, TimeUnit) .
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit).
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
PutIfAbsentOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "putIfAbsent" operation as described in Hot Rod protocol specification.
PutIfAbsentOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.PutIfAbsentOperation
 
PutKeyValueCommand - Class in org.infinispan.commands.write
Implements functionality defined by Map.put(Object, Object)
PutKeyValueCommand() - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
PutKeyValueCommand(Object, Object, boolean, CacheNotifier, long, long) - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.context.EntryLookup
Puts an entry in the registry of looked up entries in the current scope.
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
PutMapCommand - Class in org.infinispan.commands.write
 
PutMapCommand() - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutMapCommand(Map, CacheNotifier, long, long) - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutOperation<K,V> - Class in org.infinispan.atomic
An atomic put operation.
PutOperation() - Constructor for class org.infinispan.atomic.PutOperation
 
PutOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "put" as defined by Hot Rod protocol specification.
PutOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.PutOperation
 
PutOperation.Externalizer - Class in org.infinispan.atomic
 
PutOperation.Externalizer() - Constructor for class org.infinispan.atomic.PutOperation.Externalizer
 
putReferencedObject(int, Object) - Method in class org.infinispan.marshall.UnmarshalledReferences
Adds a referenced object to the list of references

Q

QueryFactory - Class in org.infinispan.query
Class that is used to build CacheQuery
QueryFactory(Cache, QueryHelper) - Constructor for class org.infinispan.query.QueryFactory
 
QueryHelper - Class in org.infinispan.query.backend

This is a TEMPORARY helper class that will be used to add the QueryInterceptor to the chain and provide Classes to Hibernate Search.

QueryHelper(Cache, Properties, Class...) - Constructor for class org.infinispan.query.backend.QueryHelper
Constructor that will take in 3 params and build the searchFactory for Hibernate Search.
QueryInterceptor - Class in org.infinispan.query.backend
This interceptor will be created when the System Property "infinispan.query.indexLocalOnly" is "false"

This type of interceptor will allow the indexing of data even when it comes from other caches within a cluster.

QueryInterceptor() - Constructor for class org.infinispan.query.backend.QueryInterceptor
 
QueryIterator - Interface in org.infinispan.query
Iterates over query results


R

raw - Variable in class org.infinispan.marshall.MarshalledValue
 
read() - Method in class org.infinispan.io.GridInputStream
 
read(byte[]) - Method in class org.infinispan.io.GridInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.GridInputStream
 
read() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read4ByteInt() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
read4ByteInt() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readArray() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readArray() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
reads an vint which is size; then an array having that size.
readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readBooleanAttribute(Element, String, String, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Retrieves the boolean value of a given attribute for the first encountered instance of elementName
readBooleanContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readBooleanContents(Element, String, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readByte() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readByte() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readByte() - Method in class org.infinispan.lucene.InfinispanIndexInput
 
readByte() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
readByteArray(int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readByteArray(int) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readBytes(byte[], int, int) - Method in class org.infinispan.lucene.InfinispanIndexInput
 
readBytes(byte[], int, int) - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
ReadCommittedEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
ReadCommittedEntry() - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry(Object, Object, long) - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry.Flags - Enum in org.infinispan.container.entries
 
readDouble() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readExternal(ObjectInput) - Method in class org.infinispan.io.GridFile.Metadata
 
readExternal(ObjectInput) - Method in class org.infinispan.loaders.bucket.Bucket
 
readExternal(ObjectInput) - Method in class org.infinispan.util.ImmutableListCopy
See ImmutableListCopy.writeExternal(java.io.ObjectOutput) for serialization format
readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readHeaderAndValidate(Transport, long, short) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
Magic | Message Id | Op code | Status | Topology Change Marker
readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLong() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readLong() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.DefaultConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.UnionConsistentHash.Externalizer
 
readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject(ObjectInput) - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
readObject(ObjectInput) - Method in interface org.infinispan.marshall.Externalizer
Read an instance from the stream.
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.LinkedListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.SetExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.SingletonListExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.ExtendedResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.RequestIgnoredResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.TransactionLog.LogEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.tree.Fqn.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.tree.NodeKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
ReadOnlyDataContainerBackedKeySet - Class in org.infinispan.util
A Set view of keys in a data container, which is read-only and has efficient contains(), unlike some data container ley sets.
ReadOnlyDataContainerBackedKeySet(DataContainer) - Constructor for class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
ReadOnlyStore - Class in org.infinispan.loaders.decorators
A decorator that makes the underlying store a CacheLoader, i.e., suppressing all write methods.
ReadOnlyStore(CacheStore) - Constructor for class org.infinispan.loaders.decorators.ReadOnlyStore
 
readPropertiesContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of a named sub element within a given element, and attempts to parse the contents as a Java properties file.
readPropertiesContents(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readString() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readString() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readStringContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of the first occurrence of elementName under the given element, trimming results of whitespace.
readUnsignedByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUnsignedInt(ObjectInput) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedInt(InputStream) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedInt(ByteBuffer) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedInt(byte[], int) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(ObjectInput) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(InputStream) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedLong(ByteBuffer) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedLong(byte[], int) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedShort() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readUnsignedShort() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readUnsignedShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUTF() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readVInt() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readVInt() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readVLong() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readVLong() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
receive(Message) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
ReclosableLatch - Class in org.infinispan.util.concurrent
A thread gat, that uses an AbstractQueuedSynchronizer.
ReclosableLatch() - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
ReclosableLatch(boolean) - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
recover(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
ReentrantPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A per-entry lock container for ReentrantLocks
ReentrantPerEntryLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
ReentrantStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A LockContainer that holds ReentrantLocks
ReentrantStripedLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
Creates a new LockContainer which uses a certain number of shared locks across all elements that need to be locked.
ReflectionUtil - Class in org.infinispan.util
Basic reflection utilities to enhance what the JDK provides.
ReflectionUtil() - Constructor for class org.infinispan.util.ReflectionUtil
 
registerComponent(Object, Class) - Method in class org.infinispan.factories.AbstractComponentRegistry
Registers a component in the registry under the given type, and injects any dependencies needed.
registerComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerComponent(Object, String) - Method in class org.infinispan.factories.ComponentRegistry
 
registerConfiguration(String, Configuration) - Method in interface org.infinispan.config.ConfigurationRegistry
Register the given configuration under the given name.
registerDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.AbstractComponentRegistry
Registers the default class loader.
registerMBeans(Set<AbstractComponentRegistry.Component>, GlobalConfiguration) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
registerMBeans() - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Performs the MBean registration.
registerNamedComponentRegistry(ComponentRegistry, String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
registerSynchronization(Synchronization) - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Registers the synchronization passed in as a parameter with the ongoing transaction.
registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
Register a Synchronization callback with this transaction.
rehash(List<Address>, List<Address>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
REHASH_CONTROL_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
RehashControlCommand - Class in org.infinispan.commands.control
A control command to coordinate rehashes that may occur when nodes join or leave a cluster, when DIST is used as a cache mode.
RehashControlCommand() - Constructor for class org.infinispan.commands.control.RehashControlCommand
 
RehashControlCommand(String, RehashControlCommand.Type, Address, Map<Object, InternalCacheValue>, ConsistentHash, ConsistentHash, List<Address>, CommandsFactory) - Constructor for class org.infinispan.commands.control.RehashControlCommand
 
RehashControlCommand(String, RehashControlCommand.Type, Address, List<WriteCommand>, List<PrepareCommand>, CommandsFactory) - Constructor for class org.infinispan.commands.control.RehashControlCommand
 
RehashControlCommand(Transport) - Constructor for class org.infinispan.commands.control.RehashControlCommand
 
RehashControlCommand.Type - Enum in org.infinispan.commands.control
 
rehashEnabled - Variable in class org.infinispan.config.Configuration.HashType
 
rehashRpcTimeout - Variable in class org.infinispan.config.Configuration.HashType
 
RehashTask - Class in org.infinispan.distribution
A task that handles the rehashing of data in the cache system wheh nodes join or leave the cluster.
RehashTask(DistributionManagerImpl, RpcManager, Configuration, CommandsFactory, DataContainer) - Constructor for class org.infinispan.distribution.RehashTask
 
rehashWait - Variable in class org.infinispan.config.Configuration.HashType
 
reincarnate() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
reincarnate() - Method in interface org.infinispan.container.entries.InternalCacheEntry
"Reincarnates" an entry.
reincarnate() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
release() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
release() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
releaseAllLocks(List<Object>) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases locks on all keys passed in.
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Destroys a connection.
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
releaseGlobalLock(boolean) - Method in class org.infinispan.loaders.LockSupportCacheStore
Based on the supplied param, releases a global read(false) or write (true) lock.
releaseGlobalLock(boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
releaseLock(Object) - Method in interface org.infinispan.container.EntryFactory
 
releaseLock(Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
releaseLock(Object) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
releaseLock(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
Release lock on the given key.
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases a lock the caller may be holding.
releaseLocks(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Cleanups the locks within the given context.
releaseLocks(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
releaseProcessingLock() - Method in interface org.infinispan.remoting.transport.DistributedSync
Releases any processing locks that may be held by the current thread.
releaseProcessingLock() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
releaseRPCBlock() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
releaseSync() - Method in interface org.infinispan.remoting.transport.DistributedSync
Releases the sync.
releaseSync() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
releaseTransport(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
releaseTransport(Transport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
releaseTransport(Transport) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
REMOTE - Static variable in class org.infinispan.jopr.CacheManagerDiscovery
 
RemoteCache<K,V> - Interface in org.infinispan.client.hotrod
Provides remote reference to a Hot Rod server/cluster.
RemoteCacheImpl<K,V> - Class in org.infinispan.client.hotrod.impl
 
RemoteCacheImpl(RemoteCacheManager, String) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
RemoteCacheManager - Class in org.infinispan.client.hotrod
Factory for RemoteCaches.
RemoteCacheManager(Marshaller, Properties, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Builds a remote cache manager that relies on the provided Marshaller for marshalling keys and values to be send over to the remote Infinispan cluster.
RemoteCacheManager(Marshaller, Properties) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(Marshaller, java.util.Properties, boolean) with start = true.
RemoteCacheManager(Properties, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Build a cache manager based on supplied properties.
RemoteCacheManager(Properties) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties, boolean), and it also starts the cache (start==true).
RemoteCacheManager(boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties), but it will try to lookup the config properties in the classpath, in a file named hotrod-client.properties.
RemoteCacheManager() - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(boolean) and it also starts the cache.
RemoteCacheManager(String, int, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Creates a remote cache manager aware of the Hot Rod server listening at host:port.
RemoteCacheManager(String, int) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(String, int, boolean) with start=true.
RemoteCacheManager(String, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
The given string should have the following structure: "host1:port2;host:port2...".
RemoteCacheManager(String) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(String, boolean), with start=true.
RemoteCacheManager(URL, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties), but it will try to lookup the config properties in supplied URL.
RemoteCacheManager(URL) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.net.URL) and it also starts the cache (start==true).
RemoteCacheManagerNotStartedException - Exception in org.infinispan.client.hotrod.exceptions
Thrown when trying to use an RemoteCache that is associated to an RemoteCacheManager that was not started.
RemoteCacheManagerNotStartedException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteCacheManagerNotStartedException
 
RemoteCacheStore - Class in org.infinispan.loaders.remote
Cache store that delegates the call to a infinispan cluster.
RemoteCacheStore() - Constructor for class org.infinispan.loaders.remote.RemoteCacheStore
 
RemoteCacheStoreConfig - Class in org.infinispan.loaders.remote
Configuration for RemoteCacheStore.
RemoteCacheStoreConfig() - Constructor for class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
RemoteCacheSupport<K,V> - Class in org.infinispan.client.hotrod.impl
Purpose: keep all delegating and unsupported methods in one place -> readability.
RemoteCacheSupport() - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
RemoteCommandsFactory - Class in org.infinispan.commands
Specifically used to create un-initialized ReplicableCommands from a byte stream.
RemoteCommandsFactory() - Constructor for class org.infinispan.commands.RemoteCommandsFactory
 
RemoteTransaction - Class in org.infinispan.transaction.xa
Defines the state of a remotely originated transaction.
RemoteTransaction(WriteCommand[], GlobalTransaction) - Constructor for class org.infinispan.transaction.xa.RemoteTransaction
 
RemoteTransaction(GlobalTransaction) - Constructor for class org.infinispan.transaction.xa.RemoteTransaction
 
RemoteTxInvocationContext - Class in org.infinispan.context.impl
Context to be used for transaction that originated remotelly.
RemoteTxInvocationContext() - Constructor for class org.infinispan.context.impl.RemoteTxInvocationContext
 
remove(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
remove(Object, Object) - Method in class org.infinispan.CacheDelegate
 
remove(Object) - Method in class org.infinispan.CacheDelegate
 
remove(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
remove(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
remove(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
remove(Object, Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
remove(Object) - Method in interface org.infinispan.container.DataContainer
Removes an entry from the cache
remove(Object) - Method in class org.infinispan.container.DefaultDataContainer
 
remove(String, boolean) - Method in class org.infinispan.io.GridFilesystem
 
remove(Object) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Removes an entry in the store.
remove(Object) - Method in interface org.infinispan.loaders.CacheStore
Removes an entry in the store.
remove(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
remove(Object) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Remove - Class in org.infinispan.loaders.modifications
Represents a CacheStore.remove(Object) modification
Remove(Object) - Constructor for class org.infinispan.loaders.modifications.Remove
 
remove(Object) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
remove() - Method in class org.infinispan.query.impl.EagerIterator
This method is not supported and should not be used.
remove() - Method in class org.infinispan.query.impl.LazyIterator
This method is not supported and should not be used.
remove(K) - Method in interface org.infinispan.tree.Node
Removes the mapping for this key from this node if it is present.
remove(K, Flag...) - Method in interface org.infinispan.tree.Node
 
remove(K) - Method in class org.infinispan.tree.NodeImpl
 
remove(K, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
remove(Fqn, K) - Method in interface org.infinispan.tree.TreeCache
Removes the mapping for this key from a Node.
remove(Fqn, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
remove(String, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
remove(String, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
remove(Fqn, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(Fqn, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(String, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(String, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(Object) - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Removes the mapping for the specified key from this map if present.
remove(Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
remove(Object) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
remove(Object) - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
remove(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
remove(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
remove(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
remove(Object) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Removes the specified element from this set if it is present.
remove0(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
REMOVE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
REMOVE_HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of removal hits.
REMOVE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_IF_UNMODIFIED_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of removal misses.
REMOVE_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
removeAddress(ConsistentHash, Address, Configuration) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Returns a new consistent hash of the same type with the given address removed.
removeAddressFromUnionConsistentHash(UnionConsistentHash, Address, Configuration) - Static method in class org.infinispan.distribution.ConsistentHashHelper
Creates a new UnionConsistentHash instance based on the old instance, removing the provided address from both target consistent hash instances in the union.
removeAll(Set<Object>) - Method in class org.infinispan.loaders.AbstractCacheStore
 
removeAll(Set<Object>) - Method in interface org.infinispan.loaders.CacheStore
Bulk remove operation
removeAll(Set<Object>) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
removeAll(Set<Object>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
removeAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ImmutableListCopy
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
removeAllCacheListeners() - Method in class org.infinispan.notifications.AbstractListenerImpl
Removes all listeners from the notifier
removeAsync(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeAsync(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeAsync(Object) - Method in interface org.infinispan.Cache
Asynchronous version of Map.remove(Object).
removeAsync(Object, Object) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.remove(Object, Object).
removeAsync(Object) - Method in class org.infinispan.CacheDelegate
 
removeAsync(Object, Object) - Method in class org.infinispan.CacheDelegate
 
removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
removeAsync(Object, Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
removeChannel(CacheListener.ChannelNotifyParams) - Method in class org.infinispan.server.websocket.CacheListener
 
removeChild(Fqn) - Method in interface org.infinispan.tree.Node
Removes a child node specified by the given relative Fqn.
removeChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
removeChild(Object) - Method in interface org.infinispan.tree.Node
Removes a child node specified by the given name.
removeChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
removeChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
removeChildren() - Method in interface org.infinispan.tree.Node
 
removeChildren(Flag...) - Method in interface org.infinispan.tree.Node
 
removeChildren() - Method in class org.infinispan.tree.NodeImpl
 
removeChildren(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
RemoveCommand - Class in org.infinispan.commands.write
 
RemoveCommand(Object, Object, CacheNotifier) - Constructor for class org.infinispan.commands.write.RemoveCommand
 
RemoveCommand() - Constructor for class org.infinispan.commands.write.RemoveCommand
 
removed(Event) - Method in class org.infinispan.demo.InfinispanDemo.CacheListener
 
removedEntries - Variable in class org.infinispan.util.Util.MapModifications
 
removeEntry(Object) - Method in class org.infinispan.loaders.bucket.Bucket
 
removeExpiredEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
removeFromIndexes(Object, Object) - Method in class org.infinispan.query.backend.QueryInterceptor
 
RemoveHandler - Class in org.infinispan.server.websocket.handlers
Cache "remove" operation handler.
RemoveHandler() - Constructor for class org.infinispan.server.websocket.handlers.RemoveHandler
 
removeIfUnmodified(byte[], long, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
RemoveIfUnmodifiedOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "removeIfUnmodified" operation as defined by Hot Rod protocol specification.
RemoveIfUnmodifiedOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[], long) - Constructor for class org.infinispan.client.hotrod.impl.operations.RemoveIfUnmodifiedOperation
 
removeInterceptor(int) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(int) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor at a specified position, where the first interceptor in the chain is at position 0 and the last one at getInterceptorChain().size() - 1.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor of specified type.
removeInterceptor(int) - Method in class org.infinispan.CacheDelegate
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.CacheDelegate
 
removeInterceptor(int) - Method in class org.infinispan.interceptors.InterceptorChain
Removes the interceptor at the given postion.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Removes all the occurences of supplied interceptor type from the chain.
removeListener(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeListener(Object) - Method in class org.infinispan.CacheDelegate
 
removeListener(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
removeListener(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
removeListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
removeListener(Object) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
removeListener(Object) - Method in interface org.infinispan.notifications.Listenable
Removes a listener from the component.
removeLocalTransaction(Transaction) - Method in class org.infinispan.transaction.xa.TransactionTable
Removes the TransactionXaAdapter corresponding to the given tx.
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Removes an entry from a Bucket, locating the relevant Bucket using the key's hash code.
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.context.EntryLookup
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
removeNode(Fqn) - Method in interface org.infinispan.tree.TreeCache
Removes a Node indicated by absolute Fqn.
removeNode(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
removeNode(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
removeNode(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
removeNode(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeObject(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
RemoveOperation<K,V> - Class in org.infinispan.atomic
An atomic remove operation.
RemoveOperation() - Constructor for class org.infinispan.atomic.RemoveOperation
 
RemoveOperation - Class in org.infinispan.client.hotrod.impl.operations
Implement "remove" operation as described in Hot Rod protocol specification.
RemoveOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.RemoveOperation
 
RemoveOperation.Externalizer - Class in org.infinispan.atomic
 
RemoveOperation.Externalizer() - Constructor for class org.infinispan.atomic.RemoveOperation.Externalizer
 
removeRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.TransactionTable
Removes the RemoteTransaction corresponding to the given tx.
removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
removeWithVersion(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeWithVersion(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
Removes the given entry only if its version matches the supplied version.
removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeWithVersionAsync(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
renameFile(String, String) - Method in class org.infinispan.lucene.InfinispanDirectory
RepeatableReadEntry - Class in org.infinispan.container.entries
An extension of ReadCommittedEntry that provides Repeatable Read semantics
RepeatableReadEntry(Object, Object, long) - Constructor for class org.infinispan.container.entries.RepeatableReadEntry
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object), which takes in lifespan parameters.
replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object), which takes in lifespan parameters.
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replace(K, V, V) - Method in class org.infinispan.CacheSupport
 
replace(K, V) - Method in class org.infinispan.CacheSupport
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replace(byte[], byte[], int, int, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V, V) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replace(K, V) - Method in interface org.infinispan.tree.Node
Replace entry for key only if currently mapped to some value.
replace(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
replace(K, V, V) - Method in interface org.infinispan.tree.Node
Replace entry for key only if currently mapped to given value.
replace(K, V, V, Flag...) - Method in interface org.infinispan.tree.Node
 
replace(K, V) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
replace(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
REPLACE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
REPLACE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_IF_UNMODIFIED_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
replaceAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.Node
Similar to Node.putAll(java.util.Map) except that it removes any entries that exists in the data map first.
replaceAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.Node
 
replaceAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.NodeImpl
 
replaceAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replaceAncestor(Fqn, Fqn) - Method in class org.infinispan.tree.Fqn
Creates a new Fqn whose ancestor has been replaced with the new ancestor passed in.
replaceAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.replace(Object, Object).
replaceAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, long, TimeUnit).
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, V) - Method in interface org.infinispan.Cache
Asynchronous version of ConcurrentMap.replace(Object, Object, Object).
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, Object, long, TimeUnit).
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
Asynchronous version of Cache.replace(Object, Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheDelegate
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, V) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V, V) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
ReplaceCommand - Class in org.infinispan.commands.write
 
ReplaceCommand() - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
ReplaceCommand(Object, Object, Object, long, long) - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
replaceIfUnmodified(byte[], byte[], int, int, long, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
ReplaceIfUnmodifiedOperation - Class in org.infinispan.client.hotrod.impl.operations
Implement "replaceIfUnmodified" as defined by Hot Rod protocol specification.
ReplaceIfUnmodifiedOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int, long) - Constructor for class org.infinispan.client.hotrod.impl.operations.ReplaceIfUnmodifiedOperation
 
replaceInterceptor(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
replaceKey(Object, Object) - Method in class org.infinispan.commands.control.LockControlCommand
 
replaceKeys(Map<Object, Object>) - Method in class org.infinispan.commands.control.LockControlCommand
 
ReplaceOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "Replace" operation as defined by Hot Rod protocol specification.
ReplaceOperation(TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.ReplaceOperation
 
replaceWithVersion(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceWithVersion(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersion(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersion(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
Removes the given value only if its version matches the supplied version.
replaceWithVersion(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersion(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceWithVersionAsync(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersionAsync(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersionAsync(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
ReplicableCommand - Interface in org.infinispan.commands
The core of the command-based cache framework.
ReplicableCommandExternalizer - Class in org.infinispan.marshall.exts
ReplicableCommandExternalizer.
ReplicableCommandExternalizer() - Constructor for class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
ReplicationException - Exception in org.infinispan.remoting
Thrown when a replication problem occurred
ReplicationException() - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationException(Throwable) - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationException(String) - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationException(String, Throwable) - Constructor for exception org.infinispan.remoting.ReplicationException
 
ReplicationInterceptor - Class in org.infinispan.interceptors
Takes care of replicating modifications to other caches in a cluster.
ReplicationInterceptor() - Constructor for class org.infinispan.interceptors.ReplicationInterceptor
 
ReplicationQueue - Class in org.infinispan.remoting
Periodically (or when certain size is exceeded) takes elements and replicates them.
ReplicationQueue() - Constructor for class org.infinispan.remoting.ReplicationQueue
 
ReplicationQueueFactory - Class in org.infinispan.factories
Factory for ReplicationQueue.
ReplicationQueueFactory() - Constructor for class org.infinispan.factories.ReplicationQueueFactory
 
replQueueInterval - Variable in class org.infinispan.config.Configuration.AsyncType
 
replQueueMaxElements - Variable in class org.infinispan.config.Configuration.AsyncType
 
replTimeout - Variable in class org.infinispan.config.Configuration.SyncType
 
REQUEST_BALANCING_STRATEGY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
REQUEST_IGNORED_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
REQUEST_MAGIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REQUEST_PARSING_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
RequestBalancingStrategy - Interface in org.infinispan.client.hotrod.impl.transport.tcp
Defines how request are distributed between the servers for replicated caches.
RequestIgnoredResponse - Class in org.infinispan.remoting.responses
Indicates that the request was ignored,
RequestIgnoredResponse.Externalizer - Class in org.infinispan.remoting.responses
 
RequestIgnoredResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.RequestIgnoredResponse.Externalizer
 
requestPermissionToJoin(Address) - Method in interface org.infinispan.distribution.DistributionManager
"Asks" a coordinator if a joiner may join.
requestPermissionToJoin(Address) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
reset() - Method in interface org.infinispan.context.FlagContainer
 
reset() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
reset() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
reset() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
reset() - Method in class org.infinispan.remoting.ReplicationQueue
 
resetNonVolatile() - Method in class org.infinispan.factories.AbstractComponentRegistry
Removes any components not annotated as @NonVolatile.
resetPassivationCount() - Method in interface org.infinispan.eviction.PassivationManager
 
resetPassivationCount() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
resetStatistics() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
Resets statistics gathered.
resetStatistics() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.TxInterceptor
 
resetStatistics() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Resets an interceptor's cache statistics
resetStatistics() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
resetStatistics() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
resolveModuleLifecycles() - Static method in class org.infinispan.util.ModuleProperties
 
resolveSchemaPath() - Static method in class org.infinispan.config.InfinispanConfiguration
 
ResourceDMBean - Class in org.infinispan.jmx
This class was entirely copied from JGroups 2.7 (same name there).
ResourceDMBean(Object) - Constructor for class org.infinispan.jmx.ResourceDMBean
 
Response - Interface in org.infinispan.remoting.responses
A response to be sent back to a remote caller
RESPONSE_MAGIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
ResponseFilter - Interface in org.infinispan.remoting.rpc
A mechanism of filtering RPC responses.
ResponseGenerator - Interface in org.infinispan.remoting.responses
A component that generates responses as is expected by different cache setups
ResponseGeneratorFactory - Class in org.infinispan.factories
Creates a ResponseGenerator
ResponseGeneratorFactory() - Constructor for class org.infinispan.factories.ResponseGeneratorFactory
 
ResponseMode - Enum in org.infinispan.remoting.rpc
Represents different handling mechanisms when dealing with remote command responses.
restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
 
resume(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
Associates the supplied InvocationContext with the calling thread.
resume(InvocationContext) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
resume(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Resume the association of the calling thread with the given transaction.
retainAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ImmutableListCopy
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
RETRIEVALS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get operations.
retrieveFromRemoteSource(Object) - Method in interface org.infinispan.distribution.DistributionManager
Retrieves a cache entry from a remote source.
retrieveFromRemoteSource(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
retrieveState(String, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
Initiates a state retrieval process from neighbouring caches.
retrieveState(String, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
retrieveState(String, Address, long) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
retrieveState(String, Address, long) - Method in interface org.infinispan.remoting.transport.Transport
Initiates a state retrieval from a specific cache (by typically invoking InboundInvocationHandler.generateState(String, java.io.OutputStream)), and applies this state to the current cache via the InboundInvocationHandler.applyState(String, java.io.InputStream) callback.
RetryOnFailureOperation - Class in org.infinispan.client.hotrod.impl.operations
Base class for all the operations that need retry logic: if the operation fails due to connection problems, try with another available connection.
RetryOnFailureOperation(TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
retryWaitTimeIncreaseFactor - Variable in class org.infinispan.config.Configuration.StateRetrievalType
 
returnPossiblePrevValue(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
returnType - Variable in class org.infinispan.tools.doclet.jmx.MBeanOperation
 
returnVersionedOperationResponse(Transport, long, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
reverseIterator() - Method in interface org.infinispan.util.ReversibleOrderedSet
 
reverseIterator() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
 
ReversibleOrderedSet<E> - Interface in org.infinispan.util
A set that allows reverse iteration of the set elements, exposed via the ReversibleOrderedSet.reverseIterator() method.
rewire() - Method in class org.infinispan.factories.AbstractComponentRegistry
Rewires components.
rewireNamedRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
RhqPluginXmlGenerator - Class in org.infinispan.tools.jopr
RhqPluginDoclet.
RhqPluginXmlGenerator() - Constructor for class org.infinispan.tools.jopr.RhqPluginXmlGenerator
 
rnd - Static variable in class org.infinispan.affinity.RndKeyGenerator
 
RndKeyGenerator - Class in org.infinispan.affinity
Key provider that relies on Random's distribution to generate keys.
RndKeyGenerator() - Constructor for class org.infinispan.affinity.RndKeyGenerator
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
rollback() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
rollback() - Method in interface org.infinispan.container.entries.CacheEntry
Rolls back changes
rollback() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
rollback(ITransaction) - Method in class org.infinispan.demos.gridfs.GridStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.AbstractCacheStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Rolls back a transaction that has been previously prepared

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

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

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

rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
rollback() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Rolls back the transaction associated with the calling thread.
rollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
Rolls back this transaction.
rollback() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Rolls back this transaction.
rollback(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionLog
 
rollback(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
ROLLBACK_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
RollbackCommand - Class in org.infinispan.commands.tx
Command corresponding to a transaction rollback.
RollbackCommand(GlobalTransaction) - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
RollbackCommand() - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
ROOT - Static variable in class org.infinispan.tree.Fqn
Immutable root Fqn.
root() - Static method in class org.infinispan.tree.Fqn
 
rootDoc - Variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
RoundRobinBalancingStrategy - Class in org.infinispan.client.hotrod.impl.transport.tcp
Round-robin implementation for RequestBalancingStrategy.
RoundRobinBalancingStrategy() - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
rpcManager - Variable in class org.infinispan.CacheDelegate
 
rpcManager - Variable in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
RpcManager - Interface in org.infinispan.remoting.rpc
Provides a mechanism for communicating with other caches in the cluster, by formatting and passing requests down to the registered Transport.
RpcManagerFactory - Class in org.infinispan.factories
A factory for the RpcManager
RpcManagerFactory() - Constructor for class org.infinispan.factories.RpcManagerFactory
 
RpcManagerImpl - Class in org.infinispan.remoting.rpc
This component really is just a wrapper around a Transport implementation, and is used to set up the transport and provide lifecycle and dependency hooks into external transport implementations.
RpcManagerImpl() - Constructor for class org.infinispan.remoting.rpc.RpcManagerImpl
 
run() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl.KeyGeneratorWorker
 
run() - Method in class org.infinispan.lucenedemo.DemoDriver
 

S

safeClose(InputStream) - Method in class org.infinispan.loaders.AbstractCacheStore
 
safeClose(OutputStream) - Method in class org.infinispan.loaders.AbstractCacheStore
 
safeClose(Statement) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(Connection) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(ResultSet) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeEquals(Object, Object) - Static method in class org.infinispan.util.Util
Null-safe equality test.
safeRelease(Lock) - Static method in class org.infinispan.util.Util
Releases a lock and swallows any IllegalMonitorStateExceptions - so it is safe to call this method even if the lock is not locked, or not locked by the current thread.
sb - Variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
ScheduledExecutorFactory - Interface in org.infinispan.executors
Used to configure and create scheduled executors
schema(XSSchema) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
SCHEMA_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
 
SCHEMA_URL_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
 
Scope - Annotation Type in org.infinispan.factories.scopes
Defines the scope of a component in a cache system.
ScopeDetector - Class in org.infinispan.factories.scopes
Retrieves the declared scope of a component
ScopeDetector() - Constructor for class org.infinispan.factories.scopes.ScopeDetector
 
Scopes - Enum in org.infinispan.factories.scopes
The different scopes that can be declared for a component in the cache system.
SearchableCacheConfiguration - Class in org.infinispan.query.backend
Class that implements SearchConfiguration so that within Infinispan-Query, there is no need for a Hibernate Core configuration object.
SearchableCacheConfiguration(Class[], Properties) - Constructor for class org.infinispan.query.backend.SearchableCacheConfiguration
 
searchCache(String) - Method in class org.infinispan.ec2demo.InfluenzaDataLoader
 
searchFactory - Variable in class org.infinispan.query.backend.QueryInterceptor
 
seek(long) - Method in class org.infinispan.lucene.InfinispanIndexInput
 
seek(long) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
seek(long) - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
SegmentReadLocker - Interface in org.infinispan.lucene.readlocks
SegmentReadLocker implementations have to make sure that segments are not deleted while they are being used by an IndexReader.
sendKeyOperation(byte[], Transport, byte, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
sendNotification(Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
sendNotification(Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
sendPutOperation(Transport, short, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
SEPARATOR - Static variable in class org.infinispan.tree.Fqn
Separator between FQN elements.
serialize(Object) - Method in class org.infinispan.loaders.jdbm.JdbmSerializer
 
serialize() - Method in class org.infinispan.marshall.MarshalledValue
 
SERVER_CACHE_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
SERVER_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
SERVER_LIST - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ServerStatistics - Interface in org.infinispan.client.hotrod
Defines the possible list of statistics defined by the Hot Rod server.
ServerStatisticsImpl - Class in org.infinispan.client.hotrod.impl
 
ServerStatisticsImpl() - Constructor for class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
set(Object) - Method in class org.infinispan.query.impl.EagerIterator
This method is not supported in and should not be called.
set(Object) - Method in class org.infinispan.query.impl.LazyIterator
This method is not supported in and should not be called.
setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setAfterInterceptor(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately after the first occurrence of an interceptor having the given class.
setAfterInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately after the first occurrence of an interceptor having the given class.
setAllowDuplicateDomains(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
setAllowDuplicateDomains(boolean) - Method in class org.infinispan.config.GlobalConfiguration
 
setAlwaysProvideInMemoryState(boolean) - Method in class org.infinispan.config.Configuration
 
setAlwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
setAsyncListenerExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncListenerExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncListenerExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncMarshalling(Boolean) - Method in class org.infinispan.config.Configuration.AsyncType
 
setAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setAsyncStoreConfig(AsyncStoreConfig) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setAsyncTransportExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncTransportExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setAsyncTransportExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setBeanClass(Class<?>) - Method in class org.infinispan.tools.schema.TreeNode
 
setBeforeInterceptor(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately before the first occurrence of an interceptor having the given class.
setBeforeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.CustomInterceptorConfig
Adds the interceptor immediately before the first occurrence of an interceptor having the given class.
setBinaryTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setBucketName(String) - Method in class org.infinispan.loaders.bucket.Bucket
 
setBucketPrefix(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setBucketTableNamePrefix(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Sets the prefix for the name of the table where the data will be stored.
setBufferSize(int) - Method in class org.infinispan.lucene.FileMetadata
 
setCache(Cache) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setCacheDbNamePrefix(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setCacheLoaderClassName(String) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
setCacheLoaderClassName(String) - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
setCacheLoaderConfigs(List<CacheLoaderConfig>) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.Configuration
 
setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheManagerNotifier(CacheManagerNotifier) - Method in class org.infinispan.factories.ComponentRegistry
 
setCacheMode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration
 
setCacheMode(String) - Method in class org.infinispan.config.Configuration
 
setCacheModeString(String) - Method in class org.infinispan.config.Configuration
 
setCacheName(String) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setCacheName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the table where data will be stored.
setCacheName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCaches(List<Address>) - Method in interface org.infinispan.distribution.ConsistentHash
Sets the collection of cache addresses in the cluster.
setCaches(List<Address>) - Method in class org.infinispan.distribution.DefaultConsistentHash
 
setCaches(List<Address>) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
setCaches(List<Address>) - Method in class org.infinispan.distribution.UnionConsistentHash
 
setCacheStore() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
setCatalogDbName(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setChanged() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setClassName(String) - Method in class org.infinispan.config.CustomInterceptorConfig
 
setCloudService(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setCloudServiceLocation(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
setCoinToss(long) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Sets the reandom number that defines the coin toss.
setComparatorClassName(String) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setCompress(boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setConcurrencyLevel(Integer) - Method in class org.infinispan.config.Configuration.LockingType
 
setConcurrencyLevel(int) - Method in class org.infinispan.config.Configuration
 
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConnectionFactoryConfig(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
Jdbc connection string for connecting to the database.
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConsistentHash(ConsistentHash) - Method in interface org.infinispan.distribution.DistributionManager
Sets the consistent hash implementation in use.
setConsistentHash(ConsistentHash) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
setConsistentHashClass(String) - Method in class org.infinispan.config.Configuration.HashType
 
setConsistentHashClass(String) - Method in class org.infinispan.config.Configuration
 
setContextFlag(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility method that sets a given context flag.
setContextFlag(AbstractInvocationContext.ContextFlag, boolean) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility value that sets or un-sets a context flag based on a boolean passed in
setCountry(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setCreated(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setCreated(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setCreated(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setCreated(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setCreateTableOnStartForBinary(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setCreateTableOnStartForStrings(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration
 
setDatabaseType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the database dialect.
setDatabaseType(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
Sets the database dialect.
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the column where the StoredEntry will be binary stored.
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDataColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the type of the column where data will be binary stored.
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDataColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDatasourceJndiLocation(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
setDatasourceJndiLocation(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setDeadlockDetectionSpinDuration(long) - Method in class org.infinispan.config.Configuration
 
setDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.InternalCacheFactory
Allows users to specify a default class loader to use for both the construction and running of the cache.
setDelegate(CacheStore) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
setDependencies(DataContainer) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
setDependencies(LockManager, DataContainer, EntryFactory) - Method in class org.infinispan.interceptors.LockingInterceptor
 
setDependencies(PassivationManager, DataContainer) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
setDistributedSyncTimeout(long) - Method in class org.infinispan.config.GlobalConfiguration
 
setDistributedSyncTimeout(Long) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
The name of the driver used for connecting to the database.
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDropTableOnExitForBinary(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDropTableOnExitForStrings(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
 
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
 
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.L1Type
 
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
setEnabled(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
setEnabled(Boolean) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setEnableDeadlockDetection(boolean) - Method in class org.infinispan.config.Configuration
 
setEvictionMaxEntries(int) - Method in class org.infinispan.config.Configuration
 
setEvictionScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setEvictionScheduledExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setEvictionScheduledExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration
 
setEvictionStrategy(String) - Method in class org.infinispan.config.Configuration
 
setEvictionThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.config.Configuration
 
setEvictionThreadPolicy(String) - Method in class org.infinispan.config.Configuration
 
setEvictionWakeUpInterval(long) - Method in class org.infinispan.config.Configuration
Eviction thread wake up interval, in milliseconds.
setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
setExecuting(Future<T>) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
setExpirationLifespan(long) - Method in class org.infinispan.config.Configuration
Expiration lifespan, in milliseconds
setExpirationMaxIdle(long) - Method in class org.infinispan.config.Configuration
Expiration max idle time, in milliseconds
setExpiryDbNamePrefix(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setExpiryQueueSize(int) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setExposeGlobalJmxStatistics(boolean) - Method in class org.infinispan.config.GlobalConfiguration
 
setExposeJmxStatistics(boolean) - Method in class org.infinispan.config.Configuration
 
setExposeJmxStats(boolean) - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
SetExternalizer - Class in org.infinispan.marshall.exts
Set externalizer for all set implementations, i.e.
SetExternalizer() - Constructor for class org.infinispan.marshall.exts.SetExternalizer
 
setFactory(String) - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
 
setFactory(String) - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
 
setFetchInMemoryState(boolean) - Method in class org.infinispan.config.Configuration
 
setFetchInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
setFetchPersistentState(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setFetchPersistentState(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setFilter(Filter) - Method in interface org.infinispan.query.CacheQuery
Allows lucene to filter the results.
setFilter(Filter) - Method in class org.infinispan.query.impl.CacheQueryImpl
Takes in a lucene filter and sets it to the filter field in the class.
setFirst(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this interceptor be the first one in the chain?
setFirstInChain(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Mainly used by unit tests to replace the interceptor chain with the starting point passed in.
setFirstResult(int) - Method in interface org.infinispan.query.CacheQuery
Sets a result with a given index to the first result.
setFirstResult(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
Sets the the result of the given integer value to the first result.
setFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Unility method that sets the value of the given flag to true.
setFlags(Flag[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
setFlags(Flag...) - Method in interface org.infinispan.context.FlagContainer
 
setFlags(Collection<Flag>) - Method in interface org.infinispan.context.FlagContainer
 
setFlags(Flag...) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setFlags(Collection<Flag>) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setFlushLockTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setFullLengthSequence(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setGanNucleoid(String) - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
setGenbankAccessionNumber(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setGenomeSequenceNumber(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.Configuration
 
setHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
 
setHost(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setHostAge(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setHostGender(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setHotRodClientProperties(Properties) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setHotRodClientPropertiesFile(String) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the column where the id will be stored.
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setIdColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
sql equivalent for java's String.
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setIdColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdentity(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setIgnoreModifications(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setIgnoreModifications(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setIndex(int) - Method in class org.infinispan.config.CustomInterceptorConfig
Put this interceptor at the specified index, after the default chain is built.
setIndexingEnabled(boolean) - Method in class org.infinispan.config.Configuration
 
setIndexLocalOnly(Boolean) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
 
setIndexLocalOnly(boolean) - Method in class org.infinispan.config.Configuration
 
setInitialRetryWaitTime(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
setInterceptor(CommandInterceptor) - Method in class org.infinispan.config.CustomInterceptorConfig
Returns a the interceptor that we want to add to the chain.
setInvocationBatchingEnabled(boolean) - Method in class org.infinispan.config.Configuration
Enables invocation batching if set to true.
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration.LockingType
 
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration
 
setIsolationLevel(String) - Method in class org.infinispan.config.Configuration
 
setJGroupsAddress(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
setJmxDomain(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
setJmxDomain(String) - Method in class org.infinispan.config.GlobalConfiguration
If JMX statistics are enabled then all 'published' JMX objects will appear under this name.
setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
setJoinComplete(boolean) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
setKey(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setKey(Object) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setKey2StringMapperClass(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setKey2StringMapperClass(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Name of the class implementing Key2StringMapper.
setL1CacheEnabled(boolean) - Method in class org.infinispan.config.Configuration
 
setL1Lifespan(long) - Method in class org.infinispan.config.Configuration
 
setL1OnRehash(boolean) - Method in class org.infinispan.config.Configuration
 
setLast(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this interceptor be the last one in the chain?
setLastModified(long) - Method in class org.infinispan.lucene.FileMetadata
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setLazyPurgingOnly(boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setLength(int) - Method in class org.infinispan.io.GridFile.Metadata
 
setLifespan(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
 
setLifespan(Long) - Method in class org.infinispan.config.Configuration.L1Type
 
setLifespan(long) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setLifespan(long) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the lifespan of the entry.
setLifespan(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Sets the lifespan of the entry.
setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setLifespan(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setLocalAddress(Address) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setLocation(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setLocation(String) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setLocation(String) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setLockAcquisitionTimeout(Long) - Method in class org.infinispan.config.Configuration.LockingType
 
setLockAcquisitionTimeout(long) - Method in class org.infinispan.config.Configuration
 
setLockAcquisitionTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setLockAcquistionTimeout(long) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setLockAcquistionTimeout(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockAcquistionTimeout(long) - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
setLockConcurrencyLevel(int) - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
Sets number of threads expected to use this class concurrently.
setLockConcurrencyLevelForBinary(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockConcurrencyLevelForStrings(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockIntention(Object) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Sets the lock this transaction intends to lock.
setMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
setMarkedForRollback(boolean) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
setMarshallerClass(String) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
 
setMarshallerClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setMarshallVersion(short) - Method in class org.infinispan.config.GlobalConfiguration
 
setMarshallVersion(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setMaxConnections(int) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setMaxEntries(Integer) - Method in class org.infinispan.config.Configuration.EvictionType
 
setMaxIdle(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setMaxIdle(long) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the maximum idle time of the entry.
setMaxIdle(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Sets the maximum idle time of the entry.
setMaxIdle(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setMaxResults(int) - Method in interface org.infinispan.query.CacheQuery
Sets the maximum number of results to the number passed in as a parameter.
setMaxResults(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
setMaxTxRetries(int) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setMBeanServerLookup(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
 
setMBeanServerLookup(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setMembers(List<Address>) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
setMode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration.ClusteringType
 
setModifications(WriteCommand[]) - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
setModificationTime(long) - Method in class org.infinispan.io.GridFile.Metadata
 
setNeedsToRejoin(boolean) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
setNetworkFuture(Future<Object>) - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
setNewMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setNewValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setNext(CommandInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Sets the next interceptor in the chain to the interceptor passed in.
setNodeName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
setNumOwners(Integer) - Method in class org.infinispan.config.Configuration.HashType
 
setNumOwners(int) - Method in class org.infinispan.config.Configuration
 
setNumRetries(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
setOldMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setOldValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setOnRehash(Boolean) - Method in class org.infinispan.config.Configuration.L1Type
 
setOriginLocal(boolean) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
setOriginLocal(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.LockControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.RehashControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
setParameters(int, Object[]) - Method in interface org.infinispan.commands.ReplicableCommand
Used by the CommandsFactory to create a command from raw data read off a stream.
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.PrepareCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ClearCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.InvalidateCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.PutMapCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setPassivation(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setPassword(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setPassword(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
Database username's password.
setPassword(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setPosition(CustomInterceptorConfig.Position) - Method in class org.infinispan.config.CustomInterceptorConfig
 
setPosition(String) - Method in class org.infinispan.config.CustomInterceptorConfig
 
setPre(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setPreload(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setProcessingThread(Thread) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
On a node, this will set the thread that handles replicatin on the given node.
setProperties(Properties) - Method in class org.infinispan.config.CustomInterceptorConfig
 
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
 
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
setProperties(Properties) - Method in class org.infinispan.config.PluggableConfigurationComponent
 
setProperties(String) - Method in class org.infinispan.config.PluggableConfigurationComponent
 
setProtein_Data(String, String) - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
setProxyHost(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setProxyPort(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setPurgeOnStartup(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setPurgeOnStartup(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setPurgerThreads(Integer) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setPurgeSynchronously(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setPurgeSynchronously(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setPushStateTimeout(Long) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
setPushStateWhenCoordinator(Boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
setPutIfAbsent(boolean) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setRehashEnabled(Boolean) - Method in class org.infinispan.config.Configuration.HashType
 
setRehashEnabled(boolean) - Method in class org.infinispan.config.Configuration
 
setRehashRpcTimeout(Long) - Method in class org.infinispan.config.Configuration.HashType
 
setRehashRpcTimeout(long) - Method in class org.infinispan.config.Configuration
 
setRehashWait(Long) - Method in class org.infinispan.config.Configuration.HashType
 
setRehashWaitTime(long) - Method in class org.infinispan.config.Configuration
 
setRemote(boolean) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setRemoteCacheName(String) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setRemoteCallTimeout(long) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
setRemoteTransaction(RemoteTransaction) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setRemoved(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setReplicatingTo(Set<Address>) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Sets the set og Address objects this node is replicating to.
setReplicationQueueScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setReplicationQueueScheduledExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setReplicationQueueScheduledExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setReplQueueInterval(Long) - Method in class org.infinispan.config.Configuration.AsyncType
 
setReplQueueInterval(long) - Method in class org.infinispan.config.Configuration
 
setReplQueueInterval(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setReplQueueMaxElements(Integer) - Method in class org.infinispan.config.Configuration.AsyncType
 
setReplQueueMaxElements(int) - Method in class org.infinispan.config.Configuration
 
setReplTimeout(Long) - Method in class org.infinispan.config.Configuration.SyncType
 
setRequestTimeout(long) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setResourceContent(ITransaction, String, InputStream, String, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
setResponseValue(Object) - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
setRetryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
setReturnCacheEntry(boolean) - Method in class org.infinispan.commands.read.GetKeyValueCommand
Will make this method to return an CacheEntry instead of the corresponding value associated with the key.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Mark the transaction associated with the calling thread for rollback only.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRootDoc(RootDoc) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
setSecure(boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setSequenceLength(int) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setServers(Collection<InetSocketAddress>) - Method in interface org.infinispan.client.hotrod.impl.transport.tcp.RequestBalancingStrategy
 
setServers(Collection<InetSocketAddress>) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
setShared(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setShutdownHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration
 
setShutdownHookBehavior(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setShutdownTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setSingletonStoreConfig(SingletonStoreConfig) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
setSingletonStoreEnabled(Boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
setSize(long) - Method in class org.infinispan.lucene.FileMetadata
 
setSort(Sort) - Method in interface org.infinispan.query.CacheQuery
Allows lucene to sort the results.
setSort(Sort) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
setSpinDuration(Long) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
 
setStackTrace(StackTraceElement[]) - Method in exception org.infinispan.marshall.NotSerializableException
 
setState(byte[]) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setState(String, byte[]) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setState(InputStream) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setState(String, InputStream) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
setStateException - Variable in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
Reference to an exception that was raised during state installation on this cache.
setStateRetrievalInitialRetryWaitTime(long) - Method in class org.infinispan.config.Configuration
 
setStateRetrievalInitialRetryWaitTime(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setStateRetrievalNumRetries(int) - Method in class org.infinispan.config.Configuration
 
setStateRetrievalRetryWaitTimeIncreaseFactor(int) - Method in class org.infinispan.config.Configuration
 
setStateRetrievalTimeout(long) - Method in class org.infinispan.config.Configuration
 
setStateRetrievalTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.TxInterceptor
 
setStatisticsEnabled(boolean) - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Enables an interceptor's cache statistics If true, the interceptor will capture statistics and make them available through the mbean.
setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
setStatus(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
setStrategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration.EvictionType
 
setStreamBufferSize(int) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setStringsTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setStringsTableNamePrefix(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the prefix for the name of the table where the data will be stored.
setSubType(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setSyncCommitPhase(boolean) - Method in class org.infinispan.config.Configuration
 
setSyncCommitPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
 
setSyncReplTimeout(long) - Method in class org.infinispan.config.Configuration
 
setSyncReplTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
 
setSyncRollbackPhase(boolean) - Method in class org.infinispan.config.Configuration
 
setSyncRollbackPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
 
setTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setTableNamePrefix(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTableNamePrefixForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTableNamePrefixForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setterMethod(Class, Class) - Static method in class org.infinispan.util.BeanUtils
Returns a Method object corresponding to a setter that sets an instance of componentClass from target.
setterName(String) - Static method in class org.infinispan.util.BeanUtils
Retrieves a setter name based on a field name passed in
setterName(Class) - Static method in class org.infinispan.util.BeanUtils
Returns a setter for a given class
setThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.config.Configuration.EvictionType
 
setThreadPoolSize(Integer) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
setTimeout(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
 
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the column where the timestamp (Long in java) will be stored.
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTimestampColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the prefix for the name of the table where the data will be stored.
setTimestampColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTimestampColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTransaction(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Just used for unit tests
setTransactionId(GlobalTransaction) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.config.Configuration
 
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration
 
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration.TransactionType
 
setTransactionSuccessful(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Change the transaction timeout for transactions started by the calling thread with the DummyBaseTransactionManager.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Change the transaction timeout for transactions started by the calling thread with the DummyUserTransaction.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
setTransport(Transport) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
setTransportClass(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setTransportClass(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
 
setTransportNodeName(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setTransportProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
 
setTransportProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setType(XSComplexType) - Method in class org.infinispan.tools.schema.TreeNode
 
setUnreliableReturnValues(Boolean) - Method in class org.infinispan.config.Configuration.UnsafeType
 
setUnsafeUnreliableReturnValues(boolean) - Method in class org.infinispan.config.Configuration
 
setupDependencies(DataContainer, CacheNotifier, Cache, InterceptorChain, DistributionManager, InvocationContextContainer, TransactionTable, Configuration) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
setUseAsyncMarshalling(boolean) - Method in class org.infinispan.config.Configuration
 
setUseDefaultRemoteCache(boolean) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setUseEagerLocking(boolean) - Method in class org.infinispan.config.Configuration
 
setUseEagerLocking(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
 
setUseFutureReturnType(boolean) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setUseFutureReturnType(boolean) - Method in interface org.infinispan.context.InvocationContext
 
setUseLazyDeserialization(boolean) - Method in class org.infinispan.config.Configuration
 
setUseLockStriping(Boolean) - Method in class org.infinispan.config.Configuration.LockingType
 
setUseLockStriping(boolean) - Method in class org.infinispan.config.Configuration
 
setUseReplQueue(Boolean) - Method in class org.infinispan.config.Configuration.AsyncType
 
setUseReplQueue(boolean) - Method in class org.infinispan.config.Configuration
 
setUserName(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
Database username.
setUserName(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setValid(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setValid(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setValid(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setValue(Object) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the value of the entry, returing the previous value
setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
setValue(Object) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setValue(Object) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setValue(V) - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
setValue(Object, String, Object) - Static method in class org.infinispan.util.ReflectionUtil
 
setValue(V) - Method in class org.infinispan.util.SimpleImmutableEntry
 
setValues(Object, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
setVersion(String) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
 
setViewId(int) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setVirusName(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setWakeUpInterval(Long) - Method in class org.infinispan.config.Configuration.EvictionType
 
setWriteSkewCheck(Boolean) - Method in class org.infinispan.config.Configuration.LockingType
 
setWriteSkewCheck(boolean) - Method in class org.infinispan.config.Configuration
 
setXaCache(TransactionXaAdapter) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
setYearFound(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
shared - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
shouldDrainWithoutLock() - Method in interface org.infinispan.distribution.TransactionLogger
Tests whether the drain() method can be called without a lock.
shouldDrainWithoutLock() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
shouldInvoke(InvocationContext) - Method in interface org.infinispan.commands.VisitableCommand
Used by the InboundInvocationHandler to determine whether the command should be invoked or not.
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.write.ClearCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.write.PutMapCommand
 
shouldModifyIndexes(InvocationContext) - Method in class org.infinispan.query.backend.LocalQueryInterceptor
 
shouldModifyIndexes(InvocationContext) - Method in class org.infinispan.query.backend.QueryInterceptor
 
shouldRetry(int) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
shouldStartAndConnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
shouldStopAndDisconnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
shutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
shutdownNow() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
shutdownTimeout - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
signalJoinCompleted() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
signalJoinInProgress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
signature - Variable in class org.infinispan.tools.doclet.jmx.MBeanOperation
 
SimpleConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Connection factory implementation that will create database connection on a per invocation basis.
SimpleConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
SimpleImmutableEntry<K,V> - Class in org.infinispan.util
Where is Java 1.6?
SimpleImmutableEntry(Map.Entry<K, V>) - Constructor for class org.infinispan.util.SimpleImmutableEntry
 
SimpleImmutableEntry(K, V) - Constructor for class org.infinispan.util.SimpleImmutableEntry
 
simpleType(XSSimpleType) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
SINGLE_RPC_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
SingleChunkIndexInput - Class in org.infinispan.lucene
SingleChunkIndexInput can be used instead of InfinispanIndexInput to read a segment when it has a size small enough to fit in a single chunk.
SingleChunkIndexInput(AdvancedCache, FileCacheKey, FileMetadata) - Constructor for class org.infinispan.lucene.SingleChunkIndexInput
 
SingleRpcCommand - Class in org.infinispan.commands.remote
Similar to MultipleRpcCommand, but it only aggregates a single command for replication.
SingleRpcCommand(String, ReplicableCommand) - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SingleRpcCommand() - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SINGLETON_LIST - Static variable in interface org.infinispan.marshall.Ids
 
SingletonListExternalizer - Class in org.infinispan.marshall.exts
SingletonListExternalizer.
SingletonListExternalizer() - Constructor for class org.infinispan.marshall.exts.SingletonListExternalizer
 
singletonStore - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
SingletonStore - Class in org.infinispan.loaders.decorators
SingletonStore is a delegating cache store used for situations when only one instance should interact with the underlying store.
SingletonStore(CacheStore, Cache, SingletonStoreConfig) - Constructor for class org.infinispan.loaders.decorators.SingletonStore
 
SingletonStore.PushStateException - Exception in org.infinispan.loaders.decorators
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
SingletonStore.PushStateException(String, Throwable) - Constructor for exception org.infinispan.loaders.decorators.SingletonStore.PushStateException
 
SingletonStore.PushStateException(Throwable) - Constructor for exception org.infinispan.loaders.decorators.SingletonStore.PushStateException
 
SingletonStore.SingletonStoreListener - Class in org.infinispan.loaders.decorators
Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
SingletonStore.SingletonStoreListener() - Constructor for class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
 
SingletonStoreConfig - Class in org.infinispan.loaders.decorators
Configuration for a singleton store
SingletonStoreConfig() - Constructor for class org.infinispan.loaders.decorators.SingletonStoreConfig
 
size() - Method in class org.infinispan.AbstractDelegatingCache
 
size() - Method in class org.infinispan.atomic.AtomicHashMap
 
size() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
size() - Method in class org.infinispan.CacheDelegate
 
size() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
size() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
size() - Method in interface org.infinispan.container.DataContainer
 
size() - Method in class org.infinispan.container.DefaultDataContainer
 
size() - Method in class org.infinispan.interceptors.InterceptorChain
Returns the number of interceptors in the chain.
size() - Method in class org.infinispan.transaction.TransactionLog
 
size() - Method in class org.infinispan.tree.Fqn
 
size() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
size() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
size() - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
size() - Method in class org.infinispan.util.FastCopyHashMap
 
size() - Method in class org.infinispan.util.FastCopyHashMap.Values
 
size() - Method in class org.infinispan.util.ImmutableListCopy
 
size() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
size() - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Returns the number of elements in this set (its cardinality).
SizeCommand - Class in org.infinispan.commands.read
Command to calculate the size of the cache
SizeCommand(DataContainer) - Constructor for class org.infinispan.commands.read.SizeCommand
 
skip(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
if this is a shared cache loader and the call is of remote origin, pass up the chain
skip(long) - Method in class org.infinispan.io.GridInputStream
 
skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
SKIP_TOKEN_REPLACEMENT - Static variable in class org.infinispan.config.InfinispanConfiguration
 
skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
sort(T[], Comparator<? super T>) - Static method in class org.infinispan.util.TimSort
 
sort(T[], int, int, Comparator<? super T>) - Static method in class org.infinispan.util.TimSort
 
spinDuration - Variable in class org.infinispan.config.Configuration.DeadlockDetectionType
 
spinDuration - Variable in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
start() - Method in class org.infinispan.AbstractDelegatingCache
 
start() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
start() - Method in class org.infinispan.CacheDelegate
 
start() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
start(ConfigurationProperties, Collection<InetSocketAddress>, AtomicInteger) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
start(ConfigurationProperties, Collection<InetSocketAddress>, AtomicInteger) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
start() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
start() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
start() - Method in class org.infinispan.demos.directory.FilesystemDirectory
 
start() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
start() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
start() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
start() - Method in class org.infinispan.factories.AbstractComponentRegistry
This starts the components in the cache, connecting to channels, starting service threads, etc.
Start - Annotation Type in org.infinispan.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache starts.
start() - Method in class org.infinispan.factories.ComponentRegistry
 
start() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
start() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
start() - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
Only does a sanity check.
start() - Method in class org.infinispan.interceptors.DistributionInterceptor
 
start() - Method in class org.infinispan.jmx.CacheJmxRegistration
Here is where the registration is being performed.
start() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
On start, the mbeans are registered.
start(ResourceContext<CacheManagerComponent>) - Method in class org.infinispan.jopr.CacheComponent
Start the resource connection
start(ResourceContext) - Method in class org.infinispan.jopr.CacheManagerComponent
Start the resource connection
start() - Method in interface org.infinispan.lifecycle.Lifecycle
 
start() - Method in class org.infinispan.loaders.AbstractCacheStore
 
start() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Validates configuration, configures and opens the Environment, then opens the databases.
start() - Method in interface org.infinispan.loaders.CacheLoader
 
start() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
start() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
start() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
start() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
start() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
start() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
start() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
start() - Method in class org.infinispan.loaders.file.FileCacheStore
 
start() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Starts the connection factory.
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
start(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
start() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
start() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
start(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
start() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
start() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
start() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
start() - Method in class org.infinispan.manager.DefaultCacheManager
 
start(RemoteCommandsFactory, StreamingMarshaller) - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
start(ClassLoader, RemoteCommandsFactory, StreamingMarshaller) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
start() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
start() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
start() - Method in class org.infinispan.remoting.ReplicationQueue
Starts the asynchronous flush queue.
start() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
start() - Method in interface org.infinispan.remoting.transport.Transport
 
start(Properties, EmbeddedCacheManager) - Method in class org.infinispan.server.websocket.WebSocketServer
 
start() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
start(RootDoc) - Static method in class org.infinispan.tools.doclet.config.ConfigDoclet
 
start(RootDoc) - Static method in class org.infinispan.tools.doclet.jmx.JmxDoclet
 
start(RootDoc) - Static method in class org.infinispan.tools.jopr.RhqPluginXmlGenerator
 
start() - Method in class org.infinispan.transaction.xa.GlobalTransactionFactory
 
start(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
start() - Method in class org.infinispan.tree.TreeCacheImpl
 
startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
startBatch() - Method in class org.infinispan.AbstractDelegatingCache
 
startBatch() - Method in class org.infinispan.batch.BatchContainer
Starts a batch
startBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
startBatch() - Method in interface org.infinispan.Cache
Starts a batch.
startBatch() - Method in class org.infinispan.CacheDelegate
 
startBatch() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
startBatch() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
startCache() - Method in class org.infinispan.manager.DefaultCacheManager
 
startCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
startChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
startDocument() - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startElement(String, String, String, Attributes) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startInterceptor() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
startJGroupsChannelIfNeeded() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
startLockManager() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
startObjectInput(InputStream, boolean) - Method in interface org.infinispan.marshall.StreamingMarshaller
Create and open a new ObjectInput for the given input stream.
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
startObjectOutput(OutputStream, boolean) - Method in class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
startObjectOutput(OutputStream, boolean) - Method in interface org.infinispan.marshall.StreamingMarshaller
Create and open an ObjectOutput instance for the given output stream.
startObjectOutput(OutputStream, boolean) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
startPrefixMapping(String, String) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startTransport(int, boolean, int, int) - Method in class org.infinispan.server.websocket.WebSocketServer
 
state - Variable in class org.infinispan.loaders.decorators.AsyncStore
 
STATE_TRANSFER_CONTROL_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
stateRetrieval - Variable in class org.infinispan.config.Configuration.ClusteringType
 
StateTransferControlCommand - Class in org.infinispan.commands.control
A command that informs caches participating in a state transfer of the various stages in the state transfer process.
StateTransferControlCommand() - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommand(boolean) - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferException - Exception in org.infinispan.statetransfer
An exception to denote problems in transferring state between cache instances in a cluster
StateTransferException() - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(String) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(String, Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferManager - Interface in org.infinispan.statetransfer
Handles generation and application of state on the cache
StateTransferManagerFactory - Class in org.infinispan.factories
Constructs StateTransferManager instances.
StateTransferManagerFactory() - Constructor for class org.infinispan.factories.StateTransferManagerFactory
 
StateTransferManagerImpl - Class in org.infinispan.statetransfer
 
StateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.StateTransferManagerImpl
 
StateTransferMonitor - Class in org.infinispan.remoting.transport.jgroups
 
StateTransferMonitor() - Constructor for class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
stats() - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
stats() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
stats() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
Stats - Interface in org.infinispan.stats
Stats.
STATS_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
STATS_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
StatsImpl - Class in org.infinispan.stats
StatsImpl.
StatsImpl(InterceptorChain) - Constructor for class org.infinispan.stats.StatsImpl
 
StatsOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements to the stats operation as defined by Hot Rod protocol specification.
StatsOperation(TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
stop() - Method in class org.infinispan.AbstractDelegatingCache
 
stop() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl.KeyGeneratorWorker
 
stop() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
stop() - Method in class org.infinispan.CacheDelegate
 
stop() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
stop() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
stop() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
stop() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
stop() - Method in class org.infinispan.factories.AbstractComponentRegistry
Stops the cache and sets the cache status to ComponentStatus.TERMINATED once it is done.
Stop - Annotation Type in org.infinispan.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache stops.
stop() - Method in class org.infinispan.factories.ComponentRegistry
 
stop() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
stop() - Method in class org.infinispan.jmx.CacheJmxRegistration
Unregister when the cache is being stoped.
stop() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
On stop, the mbeans are unregistered.
stop() - Method in class org.infinispan.jopr.CacheComponent
Tear down the rescource connection
stop() - Method in class org.infinispan.jopr.CacheManagerComponent
Tear down the rescource connection
stop() - Method in interface org.infinispan.lifecycle.Lifecycle
 
stop() - Method in class org.infinispan.loaders.AbstractCacheStore
 
stop() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Stops transaction and purge processing and closes the SleepyCat environment.
stop() - Method in interface org.infinispan.loaders.CacheLoader
 
stop() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
stop() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
stop() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
stop() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
stop() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
stop() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
stop() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Closes the connection factory, including all allocated connections etc.
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
stop() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Closes all databases, ignoring exceptions, and nulls references to all database related information.
stop() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
stop() - Method in class org.infinispan.manager.DefaultCacheManager
 
stop() - Method in class org.infinispan.marshall.jboss.ConstantObjectTable
 
stop() - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
stop() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
stop() - Method in class org.infinispan.remoting.ReplicationQueue
Stops the asynchronous flush queue.
stop() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
stop() - Method in interface org.infinispan.remoting.transport.Transport
 
stop() - Method in class org.infinispan.server.websocket.WebSocketServer
 
stop() - Method in class org.infinispan.tree.TreeCacheImpl
 
stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
stopChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Stores an entry
store(InternalCacheEntry) - Method in interface org.infinispan.loaders.CacheStore
Stores an entry
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Store - Class in org.infinispan.loaders.modifications
Modification representing CacheStore.store(org.infinispan.container.entries.InternalCacheEntry)
Store(InternalCacheEntry) - Constructor for class org.infinispan.loaders.modifications.Store
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Stores an entry in an appropriate Bucket, based on the key's hash code.
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
STORES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of put operations.
strategy - Variable in class org.infinispan.config.Configuration.EvictionType
 
strategy() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Returns type of eviction algorithm (strategy).
StreamingMarshaller - Interface in org.infinispan.marshall
A specialization of Marshaller that supports streams.
string - Variable in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
stringMode - Variable in class org.infinispan.config.Configuration.ClusteringType
 
stringRepresentation - Variable in class org.infinispan.tree.Fqn
A cached string representation of this Fqn, used by toString to it isn't calculated again every time.
stringToElement(String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
stringToKey(String) - Static method in class org.infinispan.query.backend.KeyTransformationHandler
 
StripedLock - Class in org.infinispan.util.concurrent.locks
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
StripedLock() - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
This constructor just calls StripedLock.StripedLock(int) with a default concurrency value of 20.
StripedLock(int) - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
subList(int, int) - Method in class org.infinispan.util.ImmutableListCopy
 
submit(Callable<T>) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
submit(Runnable, T) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
submit(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
SUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
ids for infinispan core classes *
successfulPut(InternalCacheEntry, boolean) - Method in class org.infinispan.container.DefaultDataContainer
 
SuccessfulResponse - Class in org.infinispan.remoting.responses
A successful response
SuccessfulResponse() - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
 
SuccessfulResponse(Object) - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
 
SuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
SuccessfulResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
supportsKey(Class) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.AbstractCacheStore
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.file.FileCacheStore
 
SurvivesRestarts - Annotation Type in org.infinispan.factories.annotations
This annotation is used for components that will be registered in the ComponentRegistry, that are meant to be retained in the component registry even after the component registry is stopped.
suspect(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
SuspectException - Exception in org.infinispan.remoting.transport.jgroups
Thrown when a member is suspected during remote method invocation
SuspectException() - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
suspend() - Method in interface org.infinispan.context.InvocationContextContainer
Disassociates thread's invocation context and returns the existing value.
suspend() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
suspend() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Suspend the association the calling thread has to a transaction, and return the suspended transaction.
sync - Variable in class org.infinispan.config.Configuration.ClusteringType
 
sync - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
syncCommitPhase - Variable in class org.infinispan.config.Configuration.TransactionType
 
SynchronizedRestarter - Class in org.infinispan.util.concurrent
A class that handles restarts of components via multiple threads.
SynchronizedRestarter() - Constructor for class org.infinispan.util.concurrent.SynchronizedRestarter
 
syncProcessor - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
syncRollbackPhase - Variable in class org.infinispan.config.Configuration.TransactionType
 
syncs - Variable in class org.infinispan.transaction.tm.DummyTransaction
 

T

tableExists(Connection, String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
tableExists(Connection) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
tableManipulation - Variable in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
TableManipulation - Class in org.infinispan.loaders.jdbc
Contains all the logic of manipulating the table, including creating it if needed and access operations like inserting, selecting etc.
TableManipulation(String, String, String, String, String, String, String) - Constructor for class org.infinispan.loaders.jdbc.TableManipulation
 
TableManipulation() - Constructor for class org.infinispan.loaders.jdbc.TableManipulation
 
target - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
TCP_NO_DELAY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
TcpTransport - Class in org.infinispan.client.hotrod.impl.transport.tcp
Transport implementation based on TCP.
TcpTransport(InetSocketAddress, TransportFactory) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
TcpTransportFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
TcpTransportFactory() - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
testImmutability(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Checks field modifications via setters
testListenerClassValidity(Class<?>) - Method in class org.infinispan.notifications.AbstractListenerImpl
Tests if a class is properly annotated as a CacheListener and returns whether callbacks on this class should be invoked synchronously or asynchronously.
testListenerMethodValidity(Method, Class, String) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
thisWillInterrupt(DeadlockDetectingGlobalTransaction) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
Based on the coin toss, determine whether this tx will continue working or this thread will be stopped.
THREAD_NAME - Static variable in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
threadPolicy - Variable in class org.infinispan.config.Configuration.EvictionType
 
threadPoolSize - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
thresholdExpired() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Returns true if batching threshold has expired, false otherwise.
TIME_SINCE_START - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of seconds since Hot Rod started.
timeout - Variable in class org.infinispan.config.Configuration.StateRetrievalType
 
TimeoutException - Exception in org.infinispan.util.concurrent
Thrown when a timeout occurred.
TimeoutException() - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
TimeoutException(String) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
timestampOfFirstEntryToExpire() - Method in class org.infinispan.loaders.bucket.Bucket
 
TimSort<T> - Class in org.infinispan.util
TimSort, backported from JDK7 sources (build openjdk-7-ea-src-b77-03_dec_2009).
tm_ - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
toArray() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
toArray(T[]) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
toArray() - Method in class org.infinispan.util.ImmutableListCopy
 
toArray(T[]) - Method in class org.infinispan.util.ImmutableListCopy
 
toArray() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
toArray(T[]) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
toAsync() - Method in enum org.infinispan.config.Configuration.CacheMode
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
toInternalCacheEntry(Object) - Method in interface org.infinispan.container.entries.InternalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
toInternalCacheValue() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Creates a representation of this entry as an InternalCacheValue.
toInternalCacheValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
toJDKByteBuffer() - Method in class org.infinispan.io.ByteBuffer
 
toJSON(String, Object, String) - Static method in class org.infinispan.server.websocket.ChannelUtils
Cache key, value and cache-name to JSON string.
TOPOLOGY_ADDRESS - Static variable in interface org.infinispan.marshall.Ids
 
TOPOLOGY_VIEW - Static variable in interface org.infinispan.marshall.Ids
 
topologyId - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Writes the current count of cachestore entries followed by a pair of byte[]s corresponding to the SleepyCat binary representation of key value.
toStream(ObjectOutput) - Method in interface org.infinispan.loaders.CacheStore
Loads the entire state into a stream, using whichever format is most efficient for the cache loader implementation.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Writes to a stream the number of entries (long) then the entries themselves.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStreamProcess(ResultSet, InputStream, ObjectOutput) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
toStreamSupport(ObjectOutput, byte, boolean) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
toString() - Method in class org.infinispan.atomic.AtomicHashMap
 
toString() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
toString() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
toString() - Method in class org.infinispan.CacheDelegate
 
toString() - Method in exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
toString() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
toString() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
toString() - Method in class org.infinispan.commands.control.LockControlCommand
 
toString() - Method in class org.infinispan.commands.control.RehashControlCommand
 
toString() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
toString() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
toString() - Method in class org.infinispan.commands.read.EntrySetCommand
 
toString() - Method in class org.infinispan.commands.read.KeySetCommand
 
toString() - Method in class org.infinispan.commands.read.SizeCommand
 
toString() - Method in class org.infinispan.commands.read.ValuesCommand
 
toString() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
toString() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
toString() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
toString() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
toString() - Method in class org.infinispan.commands.tx.PrepareCommand
 
toString() - Method in class org.infinispan.commands.write.ClearCommand
 
toString() - Method in class org.infinispan.commands.write.InvalidateCommand
 
toString() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
toString() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
toString() - Method in class org.infinispan.commands.write.PutMapCommand
 
toString() - Method in class org.infinispan.commands.write.RemoveCommand
 
toString() - Method in class org.infinispan.commands.write.ReplaceCommand
 
toString() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
toString() - Method in class org.infinispan.config.CustomInterceptorConfig
 
toString(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
toString() - Method in class org.infinispan.config.PluggableConfigurationComponent
 
toString() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
toString() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.MortalCacheValue
 
toString() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
toString() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
toString() - Method in class org.infinispan.container.entries.TransientCacheValue
 
toString() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
toString() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
toString() - Method in class org.infinispan.distribution.DefaultConsistentHash
 
toString() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
toString() - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Entry
 
toString() - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash
 
toString() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
toString() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
toString() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
toString() - Method in class org.infinispan.interceptors.InterceptorChain
 
toString() - Method in class org.infinispan.io.ByteBuffer
 
toString() - Method in class org.infinispan.io.GridFile.Metadata
 
toString() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.bucket.Bucket
 
toString() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
toString() - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
toString() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
toString() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
toString() - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.modifications.Clear
 
toString() - Method in class org.infinispan.loaders.modifications.Commit
 
toString() - Method in class org.infinispan.loaders.modifications.ModificationsList
 
toString() - Method in class org.infinispan.loaders.modifications.Prepare
 
toString() - Method in class org.infinispan.loaders.modifications.Remove
 
toString() - Method in class org.infinispan.loaders.modifications.Store
 
toString() - Method in class org.infinispan.lucene.ChunkCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileListCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileMetadata
 
toString() - Method in class org.infinispan.lucene.FileReadLockKey
 
toString() - Method in class org.infinispan.lucene.InfinispanDirectory
 
toString() - Method in class org.infinispan.manager.DefaultCacheManager
 
toString() - Method in class org.infinispan.marshall.MarshalledValue
 
toString() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
toString() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
toString(Object) - Method in class org.infinispan.query.DefaultTransformer
 
toString(Object) - Method in interface org.infinispan.query.Transformer
 
toString() - Method in exception org.infinispan.remoting.ReplicationException
 
toString() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
toString() - Method in class org.infinispan.remoting.responses.RequestIgnoredResponse
 
toString() - Method in class org.infinispan.remoting.responses.ValidResponse
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
toString() - Method in class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
toString() - Method in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
toString() - Method in class org.infinispan.tools.doclet.jmx.MBeanOperation
 
toString() - Method in class org.infinispan.tools.schema.TreeNode
 
toString() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
toString() - Method in class org.infinispan.transaction.tm.DummyXid
 
toString() - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.RemoteTransaction
 
toString() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
toString() - Method in class org.infinispan.tree.Fqn
Returns this Fqn as a string, prefixing the first element with a Fqn.SEPARATOR and joining each subsequent element with a Fqn.SEPARATOR.
toString() - Method in class org.infinispan.tree.NodeImpl
 
toString() - Method in class org.infinispan.tree.NodeKey
 
toString() - Method in class org.infinispan.tree.TreeCacheImpl
 
toString() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
toString() - Method in class org.infinispan.util.ByteArrayKey
 
toString() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
toString() - Method in exception org.infinispan.util.concurrent.TimeoutException
 
toString() - Method in class org.infinispan.util.SimpleImmutableEntry
 
toString() - Method in class org.infinispan.util.Util.MapModifications
 
toSync() - Method in enum org.infinispan.config.Configuration.CacheMode
 
TOTAL_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of entries stored in Hot Rod server.
toTypedProperties(Properties) - Method in class org.infinispan.config.AbstractConfigurationBean
Converts a given Properties instance to an instance of TypedProperties
toTypedProperties(String) - Method in class org.infinispan.config.AbstractConfigurationBean
 
toTypedProperties(Properties) - Static method in class org.infinispan.util.TypedProperties
Factory method that converts a JDK Properties instance to an instance of TypedProperties, if needed.
touch() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
touch() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Updates access timestamps on this instance
touch() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
touch() - Method in class org.infinispan.lucene.FileMetadata
 
touchFile(String) - Method in class org.infinispan.lucene.InfinispanDirectory
trace - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
trace - Variable in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
trace - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsDistSync
 
trace - Static variable in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction
 
trace - Static variable in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
trace(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
trace(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
trace(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
trace(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
trace(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
trace(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
trace(Object) - Method in interface org.infinispan.util.logging.Log
 
trace(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
trace(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
trace(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
TRANSACTION_LOG_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
TransactionalEvent - Interface in org.infinispan.notifications.cachelistener.event
An event subtype that includes a transaction context - if one exists - as well as a boolean as to whether the call originated locally or remotely.
TransactionalEventTransactionContext - Class in org.infinispan.query.backend
This class implements the TransactionContext interface.
TransactionalEventTransactionContext(TransactionManager) - Constructor for class org.infinispan.query.backend.TransactionalEventTransactionContext
Creates a new instance of NodeModifiedTransactionContext.
TransactionalLockFactory - Class in org.infinispan.lucene.locking
Factory for locks obtained in InfinispanDirectory, this factory produces instances of TransactionalSharedLuceneLock.
TransactionalLockFactory(Cache, String) - Constructor for class org.infinispan.lucene.locking.TransactionalLockFactory
 
TransactionBoundaryCommand - Interface in org.infinispan.commands.tx
An transaction boundary command that allows the retrieval of an attached GlobalTransaction
TransactionCompleted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and the transaction completes, either with a commit or a rollback.
TransactionCompletedEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionCompleted.
TransactionLog - Class in org.infinispan.transaction
Logs transactions and writes for Non-Blocking State Transfer
TransactionLog() - Constructor for class org.infinispan.transaction.TransactionLog
 
TransactionLog.LogEntry - Class in org.infinispan.transaction
 
TransactionLog.LogEntry(GlobalTransaction, WriteCommand...) - Constructor for class org.infinispan.transaction.TransactionLog.LogEntry
 
TransactionLog.LogEntry.Externalizer - Class in org.infinispan.transaction
 
TransactionLog.LogEntry.Externalizer() - Constructor for class org.infinispan.transaction.TransactionLog.LogEntry.Externalizer
 
TransactionLogger - Interface in org.infinispan.distribution
Typically adding a command, the following pattern would be used:

if (txLogger.logIfNeeded(cmd)) { // do NOT proceed with executing this command! } else { // proceed with executing this command as per normal! }

When draining, the following pattern should be used:

List<WriteCommand> c = null; while (txLogger.shouldDrainWithoutLock()) { c = txLogger.drain(); applyCommands(c); } c = txLogger.drainAndLock(); applyCommands(c); applyPendingPrepares(txLogger.getPendingPrepares()); txLogger.unlockAndDisable();

TransactionLoggerImpl - Class in org.infinispan.distribution
A transaction logger to log ongoing transactions in an efficient and thread-safe manner while a rehash is going on.
TransactionLoggerImpl() - Constructor for class org.infinispan.distribution.TransactionLoggerImpl
 
transactionManager - Variable in class org.infinispan.CacheDelegate
 
transactionManager - Variable in class org.infinispan.query.backend.QueryInterceptor
 
TransactionManagerFactory - Class in org.infinispan.factories
Uses a number of mechanisms to retrieve a transaction manager.
TransactionManagerFactory() - Constructor for class org.infinispan.factories.TransactionManagerFactory
 
transactionManagerLookup - Variable in class org.infinispan.config.Configuration.TransactionType
 
TransactionManagerLookup - Interface in org.infinispan.transaction.lookup
Factory interface, allows Cache to use different transactional systems.
transactionManagerLookupClass - Variable in class org.infinispan.config.Configuration.TransactionType
 
TransactionRegistered - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and registers a Synchronization with a registered TransactionManager.
TransactionRegisteredEvent - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionRegistered.
TransactionTable - Class in org.infinispan.transaction.xa
Repository for RemoteTransaction and TransactionXaAdapters (locally originated transactions).
TransactionTable() - Constructor for class org.infinispan.transaction.xa.TransactionTable
 
TransactionTable.StaleTransactionCleanup - Class in org.infinispan.transaction.xa
 
TransactionTable.StaleTransactionCleanup() - Constructor for class org.infinispan.transaction.xa.TransactionTable.StaleTransactionCleanup
 
TransactionXaAdapter - Class in org.infinispan.transaction.xa
This acts both as an local CacheTransaction and implementor of an XAResource that will be called by tx manager on various tx stages.
TransactionXaAdapter(GlobalTransaction, InvocationContextContainer, InterceptorChain, CommandsFactory, Configuration, TransactionTable, Transaction) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
Transformable - Annotation Type in org.infinispan.query
If you annotate your object with this, it can be used as a valid key for Infinispan to index.
Transformer - Interface in org.infinispan.query
The task of this interface is to convert keys from their original types to a String representation (which can be used in Lucene) and vice versa.
transformForL1(CacheEntry) - Method in interface org.infinispan.distribution.DistributionManager
Transforms a cache entry so it is marked for L1 rather than the primary cache data structure.
transformForL1(CacheEntry) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
TRANSIENT_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
TRANSIENT_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
TransientCacheEntry - Class in org.infinispan.container.entries
A cache entry that is transient, i.e., it can be considered expired after a period of not being used.
TransientCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
TransientCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
TransientCacheValue - Class in org.infinispan.container.entries
A transient cache value, to correspond with TransientCacheEntry
TransientCacheValue.Externalizer - Class in org.infinispan.container.entries
 
TransientCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
TransientMortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is both transient and mortal.
TransientMortalCacheEntry(Object, Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
 
TransientMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
TransientMortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
TransientMortalCacheValue - Class in org.infinispan.container.entries
A transient, mortal cache value to correspond with TransientMortalCacheEntry
TransientMortalCacheValue(Object, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue(Object, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
TransientMortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
Transport - Interface in org.infinispan.client.hotrod.impl.transport
Transport abstraction.
Transport - Interface in org.infinispan.remoting.transport
An interface that provides a communication link with remote caches.
TRANSPORT_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
transportClass - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
 
TransportException - Exception in org.infinispan.client.hotrod.exceptions
Indicates a communication exception with the Hot Rod server: e.g.
TransportException() - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
transportFactory - Variable in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
TransportFactory - Interface in org.infinispan.client.hotrod.impl.transport
Transport factory for building and managing Transport objects.
TransportFactory - Class in org.infinispan.factories
Factory for Transport implementations
TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
 
TransportObjectFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
TransportObjectFactory(TcpTransportFactory, AtomicInteger, boolean) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
TreeCache<K,V> - Interface in org.infinispan.tree
This is a tree-like facade around a Cache allowing for efficient tree-style access to cached data.
TreeCacheFactory - Class in org.infinispan.tree
Factory class that contains API for users to create instances of TreeCache
TreeCacheFactory() - Constructor for class org.infinispan.tree.TreeCacheFactory
 
TreeCacheImpl<K,V> - Class in org.infinispan.tree
 
TreeCacheImpl(Cache<?, ?>) - Constructor for class org.infinispan.tree.TreeCacheImpl
 
TreeNode - Class in org.infinispan.tools.schema
TreeNode of Infinispan configuration
TreeNode(String, TreeNode) - Constructor for class org.infinispan.tools.schema.TreeNode
 
TreeNode() - Constructor for class org.infinispan.tools.schema.TreeNode
 
TreeStructureSupport - Class in org.infinispan.tree
 
TreeStructureSupport(Cache<?, ?>, BatchContainer, InvocationContextContainer) - Constructor for class org.infinispan.tree.TreeStructureSupport
 
TreeWalker - Interface in org.infinispan.tools.schema
TreeWalker visitor
trim(String) - Static method in class org.infinispan.io.GridFile
 
tryAcquire(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
tryLock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryLock(long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryRelease(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryReleaseShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
TwoWayKey2StringMapper - Interface in org.infinispan.loaders.jdbc.stringbased
Extends Key2StringMapper and allows a bidirectional transformation between keys and strings.
TxInterceptor - Class in org.infinispan.interceptors
Interceptor in charge with handling transaction related operations, e.g enlisting cache as an transaction participant, propagating remotely initiated changes.
TxInterceptor() - Constructor for class org.infinispan.interceptors.TxInterceptor
 
TxInvocationContext - Interface in org.infinispan.context.impl
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
txMods - Variable in class org.infinispan.interceptors.InvalidationInterceptor
 
txTable - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
type - Variable in class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
TypedProperties - Class in org.infinispan.util
Type-aware properties.
TypedProperties(Properties) - Constructor for class org.infinispan.util.TypedProperties
Copy constructor
TypedProperties() - Constructor for class org.infinispan.util.TypedProperties
Default constructor that returns an empty instance
TypedPropertiesAdapter - Class in org.infinispan.config
TypedPropertiesAdapter is JAXB XmlAdapter for TypedProperties.
TypedPropertiesAdapter() - Constructor for class org.infinispan.config.TypedPropertiesAdapter
 

U

uc(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Safely converts a String to upper case.
uc(String) - Method in class org.infinispan.config.CustomInterceptorConfig
 
unblock() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
unBoundedDataContainer(int) - Static method in class org.infinispan.container.DefaultDataContainer
 
UnclosableObjectInputStream - Class in org.infinispan.io
A delegating ObjectInput that delegates all methods except ObjectInput.close().
UnclosableObjectInputStream(ObjectInput) - Constructor for class org.infinispan.io.UnclosableObjectInputStream
 
UnclosableObjectOutputStream - Class in org.infinispan.io
An unclosable version of an ObjectOutput.
UnclosableObjectOutputStream(ObjectOutput) - Constructor for class org.infinispan.io.UnclosableObjectOutputStream
 
UNION_CONSISTENT_HASH - Static variable in interface org.infinispan.marshall.Ids
 
UnionConsistentHash - Class in org.infinispan.distribution
A delegating wrapper that locates keys by getting a union of locations reported by two other ConsistentHash implementations it delegates to.
UnionConsistentHash(ConsistentHash, ConsistentHash) - Constructor for class org.infinispan.distribution.UnionConsistentHash
 
UnionConsistentHash.Externalizer - Class in org.infinispan.distribution
 
UnionConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.UnionConsistentHash.Externalizer
 
UNKNOWN_COMMAND_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
UNKNOWN_VERSION_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
unlock(String) - Method in class org.infinispan.loaders.LockSupportCacheStore
Release the locks (either read or write).
unlock(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases the lock passed in, held by the specified owner
unlock(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases locks present in an invocation context and transaction entry, if one is available.
unlock(Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
unlock(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
unlock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
unlockAndDisable() - Method in interface org.infinispan.distribution.TransactionLogger
Unlocks and disables the transaction logger.
unlockAndDisable() - Method in class org.infinispan.distribution.TransactionLoggerImpl
 
unmarshal(Configuration.ClusteringType) - Method in class org.infinispan.config.Configuration.ClusteringTypeAdapter
 
unmarshal(PropertiesType) - Method in class org.infinispan.config.TypedPropertiesAdapter
 
unmarshall(StreamingMarshaller, InputStream) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
UnmarshalledReferences - Class in org.infinispan.marshall
An efficient array-based list of referenced objects, using the reference id as a subscript for the array.
UnmarshalledReferences() - Constructor for class org.infinispan.marshall.UnmarshalledReferences
 
unmarshallMap(Map, ObjectInput) - Static method in class org.infinispan.marshall.MarshallUtil
 
unregisterCacheMBean() - Method in class org.infinispan.jmx.CacheJmxRegistration
 
unregisterConfiguration(String) - Method in interface org.infinispan.config.ConfigurationRegistry
Unregisters the named configuration.
unregisterMBeans(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
unregisterMBeans() - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Unregisters all the MBeans registered through ComponentsJmxRegistration.registerMBeans().
unregisterNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
unreliableReturnValues - Variable in class org.infinispan.config.Configuration.UnsafeType
 
unsetContextFlag(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility method that un-sets a context flag.
unsetFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Utility method that sets the value of the flag to false.
UnsignedNumeric - Class in org.infinispan.io
Helper to read and write unsigned numerics
UnsignedNumeric() - Constructor for class org.infinispan.io.UnsignedNumeric
 
UNSUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
UnsuccessfulResponse - Class in org.infinispan.remoting.responses
An unsuccessful response
UnsuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
UnsuccessfulResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
UnsupportedKeyTypeException - Exception in org.infinispan.loaders.jdbc.stringbased
Exception thrown by JdbcStringBasedCacheStore when one tries to persist a StoredEntry with an unsupported key type.
UnsupportedKeyTypeException(Object) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String, Throwable) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(Throwable) - Constructor for exception org.infinispan.loaders.jdbc.stringbased.UnsupportedKeyTypeException
 
UNSURE_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
UnsureResponse - Class in org.infinispan.remoting.responses
An unsure response - used with Dist - essentially asks the caller to check the next response from the next node since the sender is in a state of flux (probably in the middle of rebalancing)
UnsureResponse() - Constructor for class org.infinispan.remoting.responses.UnsureResponse
 
UnsureResponse.Externalizer - Class in org.infinispan.remoting.responses
 
UnsureResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
update(InternalCacheEntry, long, long) - Method in class org.infinispan.container.entries.InternalEntryFactory
Sets the values on the given internal cache entry, potentially reconstructing the entry to the most appropriate type (Mortal, Immortal, Transient or TransientMortal) based on the lifespan and maxIdle being set.
update() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
updateBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Updates a bucket in the store with the Bucket passed in to the method.
updateBucket(Bucket) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
updateBucket(Bucket) - Method in class org.infinispan.loaders.file.FileCacheStore
 
updateBucket(Bucket) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
updateDomain(ComponentsJmxRegistration, GlobalComponentRegistry, MBeanServer) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
updateDomain(ComponentsJmxRegistration, GlobalComponentRegistry, MBeanServer) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
updateHashFunction(LinkedHashMap<InetSocketAddress, Integer>, int, short, int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
updateHashFunction(LinkedHashMap<InetSocketAddress, Integer>, int, short, int) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
updateIndexes(Object, Object) - Method in class org.infinispan.query.backend.QueryInterceptor
 
updateServers(Collection<InetSocketAddress>) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
updateServers(Collection<InetSocketAddress>) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
useChainingCacheLoader() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
useEagerLocking - Variable in class org.infinispan.config.Configuration.TransactionType
 
useLockStriping - Variable in class org.infinispan.config.Configuration.LockingType
 
useReplQueue - Variable in class org.infinispan.config.Configuration.AsyncType
 
Util - Class in org.infinispan.util
General utility methods used throughout the Infinispan code base.
Util.MapModifications - Class in org.infinispan.util
Static inner class that holds 3 maps - for data added, removed and modified.
Util.MapModifications() - Constructor for class org.infinispan.util.Util.MapModifications
 

V

validateObject(Object, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
This will be called by the test thread when testWhileIdle==true.
VALIDATING_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
 
validOptions(String[][], DocErrorReporter) - Static method in class org.infinispan.tools.doclet.config.ConfigDoclet
 
validOptions(String[][], DocErrorReporter) - Static method in class org.infinispan.tools.doclet.jmx.JmxDoclet
 
validOptions(String[][], DocErrorReporter) - Static method in class org.infinispan.tools.jopr.RhqPluginXmlGenerator
 
ValidResponse - Class in org.infinispan.remoting.responses
A valid response
ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
 
value - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
value - Variable in class org.infinispan.commands.write.RemoveCommand
When not null, value indicates that the entry should only be removed if the key is mapped to this value.
value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
VALUE - Static variable in interface org.infinispan.server.websocket.OpHandler
 
VALUE_SIZE_ESTIMATE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
valueOf(String) - Static method in enum org.infinispan.atomic.NullDelta
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.commands.control.RehashControlCommand.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.config.Configuration.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.context.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.context.impl.AbstractInvocationContext.ContextFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.eviction.EvictionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.eviction.EvictionThreadPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.factories.scopes.Scopes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.lifecycle.ComponentStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.loaders.jdbc.DatabaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.loaders.modifications.Modification.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.transport.DistributedSync.SyncResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.server.core.transport.NoState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.tree.NodeKey.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.concurrent.BoundedConcurrentHashMap.Eviction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns the enum constant of this type with the specified name.
values() - Method in class org.infinispan.AbstractDelegatingCache
 
values() - Method in class org.infinispan.atomic.AtomicHashMap
 
values() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
values() - Static method in enum org.infinispan.atomic.NullDelta
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.Cache
Returns a collection view of the values contained in this cache.
values() - Method in class org.infinispan.CacheDelegate
 
values() - Static method in enum org.infinispan.client.hotrod.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
values() - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
values() - Static method in enum org.infinispan.commands.control.RehashControlCommand.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.config.Configuration.CacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.container.DataContainer
 
values() - Method in class org.infinispan.container.DefaultDataContainer
 
values() - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.context.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.context.impl.AbstractInvocationContext.ContextFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.eviction.EvictionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.eviction.EvictionThreadPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.factories.scopes.Scopes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.lifecycle.ComponentStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.loaders.jdbc.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.loaders.modifications.Modification.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.transport.DistributedSync.SyncResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.server.core.transport.NoState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.tree.NodeKey.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.infinispan.util.AbstractMap
 
values() - Method in class org.infinispan.util.BidirectionalLinkedHashMap
 
values() - Static method in enum org.infinispan.util.concurrent.BoundedConcurrentHashMap.Eviction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Collection view of the values contained in this map.
values() - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.util.FastCopyHashMap
 
ValuesCommand - Class in org.infinispan.commands.read
ValuesCommand.
ValuesCommand(DataContainer) - Constructor for class org.infinispan.commands.read.ValuesCommand
 
verify() - Method in class org.infinispan.util.ModuleProperties
 
Version - Class in org.infinispan.client.hotrod
Defines client and protocol version.
Version() - Constructor for class org.infinispan.client.hotrod.Version
 
version - Variable in class org.infinispan.config.GlobalConfiguration.SerializationType
 
Version - Class in org.infinispan
Contains version information about this release of Infinispan.
Version() - Constructor for class org.infinispan.Version
 
version - Static variable in class org.infinispan.Version
 
VersionAwareMarshaller - Class in org.infinispan.marshall
A delegate to various other marshallers like JBossMarshaller.
VersionAwareMarshaller() - Constructor for class org.infinispan.marshall.VersionAwareMarshaller
 
VersionedOperationResponse - Class in org.infinispan.client.hotrod.impl
 
VersionedOperationResponse(byte[], VersionedOperationResponse.RspCode) - Constructor for class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
VersionedOperationResponse.RspCode - Enum in org.infinispan.client.hotrod.impl
 
VersionedValue<V> - Interface in org.infinispan.client.hotrod
Besides the key and value, also contains an version.
VersionedValueImpl<V> - Class in org.infinispan.client.hotrod.impl
 
VersionedValueImpl(long, V) - Constructor for class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
viewAccepted(View) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
viewChange(ViewChangedEvent) - Method in class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
The cluster formation changed, so determine whether the current cache stopped being the coordinator or became the coordinator.
ViewChanged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology changes (i.e., a member joins or leaves the cluster).
ViewChangedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with ViewChanged.
viewChangeEvent(ViewChangedEvent) - Method in class org.infinispan.demo.InfinispanDemo.CacheListener
 
visit(E) - Method in class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Visits the key in the underlying Map, by performing a Map.get(Object).
VisitableBidirectionalLinkedHashSet<E> - Class in org.infinispan.util
Similar to the JDK's LinkedHashSet except that it sets the underlying LinkedHashMap's accessOrder constructor parameter to true, allowing for recording of visits.
VisitableBidirectionalLinkedHashSet(boolean, int, float) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new, empty linked hash set with the specified initial capacity and load factor.
VisitableBidirectionalLinkedHashSet(boolean, int) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new, empty linked hash set with the specified initial capacity and the default load factor (0.75).
VisitableBidirectionalLinkedHashSet(boolean) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new, empty linked hash set with the default initial capacity (16) and load factor (0.75).
VisitableBidirectionalLinkedHashSet(boolean, Collection<? extends E>) - Constructor for class org.infinispan.util.VisitableBidirectionalLinkedHashSet
Constructs a new linked hash set with the same elements as the specified collection.
VisitableCommand - Interface in org.infinispan.commands
A type of command that can accept Visitors, such as CommandInterceptors.
visitAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitAsyncStoreConfig(AsyncStoreConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitCacheLoaderConfig(CacheLoaderConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCacheLoaderConfig(CacheLoaderConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in interface org.infinispan.commands.Visitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitClusteringType(Configuration.ClusteringType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitClusteringType(Configuration.ClusteringType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitClusteringType(Configuration.ClusteringType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitCollection(InvocationContext, Collection<? extends VisitableCommand>) - Method in class org.infinispan.commands.AbstractVisitor
Helper method to visit a collection of VisitableCommands.
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in interface org.infinispan.commands.Visitor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitConfiguration(Configuration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitConfiguration(Configuration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitConfiguration(Configuration) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
 
visitCustomInterceptorConfig(CustomInterceptorConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCustomInterceptorConfig(CustomInterceptorConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in interface org.infinispan.commands.Visitor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in interface org.infinispan.commands.Visitor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
visitEvictionType(Configuration.EvictionType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitEvictionType(Configuration.EvictionType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitEvictionType(Configuration.EvictionType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitFactoryClassWithPropertiesType(GlobalConfiguration.FactoryClassWithPropertiesType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitFactoryClassWithPropertiesType(GlobalConfiguration.FactoryClassWithPropertiesType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitGlobalConfiguration(GlobalConfiguration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitGlobalJmxStatisticsType(GlobalConfiguration.GlobalJmxStatisticsType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitGlobalJmxStatisticsType(GlobalConfiguration.GlobalJmxStatisticsType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitHashType(Configuration.HashType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitHashType(Configuration.HashType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitHashType(Configuration.HashType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitInfinispanConfiguration(InfinispanConfiguration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitInfinispanConfiguration(InfinispanConfiguration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in interface org.infinispan.commands.Visitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in interface org.infinispan.commands.Visitor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitL1Type(Configuration.L1Type) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitL1Type(Configuration.L1Type) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitL1Type(Configuration.L1Type) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in interface org.infinispan.commands.Visitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitLockingType(Configuration.LockingType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitLockingType(Configuration.LockingType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitLockingType(Configuration.LockingType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.XMLTreeOutputWalker
 
visitNode(TreeNode) - Method in interface org.infinispan.tools.schema.TreeWalker
 
Visitor - Interface in org.infinispan.commands
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ImplicitEagerLockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DistTxInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.LockingInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitSerializationType(GlobalConfiguration.SerializationType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitSerializationType(GlobalConfiguration.SerializationType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitShutdownType(GlobalConfiguration.ShutdownType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitShutdownType(GlobalConfiguration.ShutdownType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitSingletonStoreConfig(SingletonStoreConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in interface org.infinispan.commands.Visitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitSyncType(Configuration.SyncType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitSyncType(Configuration.SyncType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitSyncType(Configuration.SyncType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitTransportType(GlobalConfiguration.TransportType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitTransportType(GlobalConfiguration.TransportType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitTransportType(GlobalConfiguration.TransportType) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in interface org.infinispan.commands.Visitor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 

W

waitForJoinToComplete() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
waitForState() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
wakeUpInterval - Variable in class org.infinispan.config.Configuration.EvictionType
 
warn(Object, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
warn(Object, Throwable, Object...) - Method in class org.infinispan.util.logging.AbstractLogImpl
 
warn(Object) - Method in class org.infinispan.util.logging.JDKLogImpl
 
warn(Object, Throwable) - Method in class org.infinispan.util.logging.JDKLogImpl
 
warn(Object, Object...) - Method in interface org.infinispan.util.logging.Log
 
warn(Object, Throwable, Object...) - Method in interface org.infinispan.util.logging.Log
 
warn(Object) - Method in interface org.infinispan.util.logging.Log
 
warn(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
warn(Object) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
warn(Object, Throwable) - Method in class org.infinispan.util.logging.Log4JLogImpl
 
WebSocketServer - Class in org.infinispan.server.websocket
An HTTP server which serves Web Socket requests on an Infinispan cacheManager.
WebSocketServer() - Constructor for class org.infinispan.server.websocket.WebSocketServer
 
WebSocketServerHandler - Class in org.infinispan.server.websocket
Web Socket Server Handler (Netty).
WebSocketServerHandler(CacheContainer, Map<String, OpHandler>, Map<String, Cache>) - Constructor for class org.infinispan.server.websocket.WebSocketServerHandler
 
wildcard(XSWildcard) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
wireDependencies(Object) - Method in class org.infinispan.factories.AbstractComponentRegistry
Wires an object instance with dependencies annotated with the Inject annotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in the ComponentRegistry.
withAnnotationDeclared(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ClassFinder
 
withAnnotationPresent(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ClassFinder
 
withAnnotationPresent(Class<? extends Annotation>) - Static method in class org.infinispan.util.ClassFinder
 
withFlags(Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
withFlags(Flag...) - Method in interface org.infinispan.AdvancedCache
A builder-style method that adds flags to any API call.
withFlags(Flag...) - Method in class org.infinispan.CacheDelegate
 
withFlags(Flag...) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
withFlags(Flag...) - Method in interface org.infinispan.client.hotrod.RemoteCache
Applies one or more Flags to the scope of a single invocation.
WithinThreadExecutor - Class in org.infinispan.util.concurrent
An executor that works within the current thread.
WithinThreadExecutor() - Constructor for class org.infinispan.util.concurrent.WithinThreadExecutor
 
wrapEntryForReading(InvocationContext, Object) - Method in interface org.infinispan.container.EntryFactory
Wraps an entry for reading.
wrapEntryForReading(InvocationContext, Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForWriting(InvocationContext, Object, boolean, boolean, boolean, boolean, boolean) - Method in interface org.infinispan.container.EntryFactory
Wraps an entry for writing.
wrapEntryForWriting(InvocationContext, InternalCacheEntry, boolean, boolean, boolean, boolean, boolean) - Method in interface org.infinispan.container.EntryFactory
Wraps an entry for writing.
wrapEntryForWriting(InvocationContext, Object, boolean, boolean, boolean, boolean, boolean) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForWriting(InvocationContext, InternalCacheEntry, boolean, boolean, boolean, boolean, boolean) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapMap(Map<Object, Object>, Set<MarshalledValue>, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
writable - Variable in class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
write(byte[], int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.io.GridOutputStream
 
write(byte[]) - Method in class org.infinispan.io.GridOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.GridOutputStream
 
write(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[]) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeArray(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeArray(byte[]) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(short) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeByte(short) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(byte) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
writeBytes(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeBytes(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBytes(byte[], int, int) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
WriteCommand - Interface in org.infinispan.commands.write
A command that modifies the cache in some way
writeCommitLog(StreamingMarshaller, ObjectOutput) - Method in class org.infinispan.transaction.TransactionLog
 
writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeExternal(ObjectOutput) - Method in class org.infinispan.io.GridFile.Metadata
 
writeExternal(ObjectOutput) - Method in class org.infinispan.util.ImmutableListCopy
Format: - entry array size (int) - elements (Object)
writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeHeader(Transport, short) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeLong(long) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeLong(long) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.distribution.DefaultConsistentHash.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.distribution.ExperimentalDefaultConsistentHash.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.distribution.UnionConsistentHash.Externalizer
 
writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
writeObject(ObjectOutput, Object) - Method in interface org.infinispan.marshall.Externalizer
Write the predefined object reference to the stream.
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.exts.LinkedListExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.exts.SetExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.exts.SingletonListExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.responses.ExtendedResponse.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.responses.RequestIgnoredResponse.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.transaction.TransactionLog.LogEntry.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.transaction.xa.DeadlockDetectingGlobalTransaction.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.tree.Fqn.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.tree.NodeKey.Externalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
writePendingPrepares(StreamingMarshaller, ObjectOutput) - Method in class org.infinispan.transaction.TransactionLog
 
writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeSkewCheck - Variable in class org.infinispan.config.Configuration.LockingType
 
writeString(String) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeString(String) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeUnsignedInt(ObjectOutput, int) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedInt(OutputStream, int) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedInt(ByteBuffer, int) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedInt(byte[], int, int) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(ObjectOutput, long) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(OutputStream, long) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedLong(ByteBuffer, long) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedLong(byte[], int, long) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUTF(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeVInt(int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeVInt(int) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeVLong(long) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeVLong(long) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 

X

xid - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
XmlConfigHelper - Class in org.infinispan.config.parsing
A simple XML utility class for reading configuration elements
XmlConfigHelper() - Constructor for class org.infinispan.config.parsing.XmlConfigHelper
 
XmlConfigurationParser - Interface in org.infinispan.config.parsing
Implementations of this interface are responsible for parsing XML configuration files.
XMLTreeOutputWalker - Class in org.infinispan.tools.doclet.config
TreeWalker that generates XML pretty print of the configuration tree
XMLTreeOutputWalker(StringBuilder) - Constructor for class org.infinispan.tools.doclet.config.XMLTreeOutputWalker
 
xpath(XSXPath) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
XSOMSchemaTreeWalker - Class in org.infinispan.tools.schema
XSOMSchemaTreeWalker traverses XML schema and builds a tree with elements we need out of that schema
XSOMSchemaTreeWalker(XSSchema, String) - Constructor for class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 

_

_list(Object) - Method in class org.infinispan.io.GridFile
 
_listFiles(Object) - Method in class org.infinispan.io.GridFile
 

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

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