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

abortIfRemoteTransactionInvalid(TxInvocationContext, AbstractTransactionBoundaryCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
abortingJoin(Exception) - Method in interface org.infinispan.util.logging.Log
 
AbstractAdapter<T extends Event<?,?>> - Class in org.infinispan.cdi.event.cache
 
AbstractAdapter(Event<T>) - Constructor for class org.infinispan.cdi.event.cache.AbstractAdapter
 
AbstractAdapter<T extends Event> - Class in org.infinispan.cdi.event.cachemanager
 
AbstractAdapter(Event<T>) - Constructor for class org.infinispan.cdi.event.cachemanager.AbstractAdapter
 
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
 
AbstractCacheTransaction - Class in org.infinispan.transaction
Base class for local and remote transaction.
AbstractCacheTransaction(GlobalTransaction, int) - Constructor for class org.infinispan.transaction.AbstractCacheTransaction
 
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(ClassLoader) - 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.ch
An abstract consistent hash implementation that handles common implementations of certain methods.
AbstractConsistentHash() - Constructor for class org.infinispan.distribution.ch.AbstractConsistentHash
 
AbstractCustomInterceptorsConfigurationChildBuilder<T> - Class in org.infinispan.configuration.cache
 
AbstractCustomInterceptorsConfigurationChildBuilder(CustomInterceptorsConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
AbstractDataCommand - Class in org.infinispan.commands.read
 
AbstractDataCommand(Object, Set<Flag>) - 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, Set<Flag>) - Constructor for class org.infinispan.commands.write.AbstractDataWriteCommand
 
AbstractDecoratorConfigurationBean - Class in org.infinispan.loaders.decorators
Class to aid decorators to be able to fluently modify parent properties.
AbstractDecoratorConfigurationBean() - Constructor for class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
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
 
AbstractDelegatingEmbeddedCacheManager - Class in org.infinispan.manager
This is a convenient base class for implementing a cache manager delegate.
AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
AbstractDelegatingMarshaller - Class in org.infinispan.marshall
With the introduction of global and cache marshallers, there's a need to separate marshallers but still rely on the same marshalling backend as previously.
AbstractDelegatingMarshaller() - Constructor for class org.infinispan.marshall.AbstractDelegatingMarshaller
 
AbstractDelegatingStore - Class in org.infinispan.loaders.decorators
Simple delegate that delegates all calls.
AbstractDelegatingStore(CacheStore) - Constructor for class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
AbstractEmbeddedCacheManagerFactory - Class in org.infinispan.spring
An abstract base class for factories creating cache managers that are backed by an EmbeddedCacheManager.
AbstractEmbeddedCacheManagerFactory() - Constructor for class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
AbstractEmbeddedCacheManagerFactory.ConfigurationContainer - Class in org.infinispan.spring
 
AbstractEmbeddedCacheManagerFactory.GlobalConfigurationOverrides - Class in org.infinispan.spring
 
AbstractEmbeddedCacheManagerFactory.GlobalConfigurationOverrides() - Constructor for class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory.GlobalConfigurationOverrides
 
AbstractEnlistmentAdapter - Class in org.infinispan.transaction
Base class for both Sync and XAResource enlistment adapters.
AbstractEnlistmentAdapter(CacheTransaction, CommandsFactory, RpcManager, TransactionTable, ClusteringDependentLogic, Configuration) - Constructor for class org.infinispan.transaction.AbstractEnlistmentAdapter
 
AbstractEnlistmentAdapter(CommandsFactory, RpcManager, TransactionTable, ClusteringDependentLogic, Configuration) - Constructor for class org.infinispan.transaction.AbstractEnlistmentAdapter
 
AbstractEventBridge<T> - Class in org.infinispan.cdi.event
 
AbstractEventBridge() - Constructor for class org.infinispan.cdi.event.AbstractEventBridge
 
AbstractExternalizer<T> - Class in org.infinispan.marshall
Base class for AdvancedExternalizer implementations that offers default implementations for some of its methods.
AbstractExternalizer() - Constructor for class org.infinispan.marshall.AbstractExternalizer
 
AbstractFileLookup - Class in org.infinispan.util
 
AbstractFileLookup() - Constructor for class org.infinispan.util.AbstractFileLookup
 
AbstractFlagAffectedCommand - Class in org.infinispan.commands
Base class for those commands that can carry flags.
AbstractFlagAffectedCommand() - Constructor for class org.infinispan.commands.AbstractFlagAffectedCommand
 
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
AbstractInternalCacheEntry() - Constructor for class org.infinispan.container.entries.AbstractInternalCacheEntry
 
AbstractInternalCacheEntry(Object) - Constructor for class org.infinispan.container.entries.AbstractInternalCacheEntry
 
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
 
AbstractInvocationContextContainer - Class in org.infinispan.context
Base class for InvocationContextContainer implementations.
AbstractInvocationContextContainer() - Constructor for class org.infinispan.context.AbstractInvocationContextContainer
 
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
 
AbstractJBossMarshaller - Class in org.infinispan.marshall.jboss
Common parent for both embedded and standalone JBoss Marshalling-based marshallers.
AbstractJBossMarshaller() - Constructor for class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
AbstractJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.marshall.jboss
 
AbstractJBossMarshaller.DebuggingExceptionListener() - Constructor for class org.infinispan.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
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<T> - Class in org.infinispan.client.hotrod.impl.operations
Basic class for all hot rod operations that manipulate a key.
AbstractKeyOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
AbstractKeyValueOperation<T> - Class in org.infinispan.client.hotrod.impl.operations
Base class for all operations that manipulate a key and a value.
AbstractKeyValueOperation(Codec, 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
 
AbstractLoaderConfiguration - Class in org.infinispan.configuration.cache
 
AbstractLoaderConfigurationBuilder<T extends AbstractLoaderConfiguration> - Class in org.infinispan.configuration.cache
 
AbstractLoaderConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
 
AbstractLoaderConfigurationChildBuilder<T> - Class in org.infinispan.configuration.cache
 
AbstractLoadersConfigurationChildBuilder<T> - Class in org.infinispan.configuration.cache
 
AbstractLoadersConfigurationChildBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractLoadersConfigurationChildBuilder
 
AbstractLocalCommand - Class in org.infinispan.commands.read
Abstract class
AbstractLocalCommand() - Constructor for class org.infinispan.commands.read.AbstractLocalCommand
 
AbstractLockContainer<L extends Lock> - Class in org.infinispan.util.concurrent.locks.containers
 
AbstractLockContainer() - Constructor for class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
 
AbstractLockingInterceptor - Class in org.infinispan.interceptors.locking
Base class for various locking interceptors in this package.
AbstractLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
AbstractLockSupportCacheStoreConfiguration - Class in org.infinispan.configuration.cache
Lock supporting cache store configuration.
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<L extends Lock> - 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
 
AbstractRemoteCacheManagerFactory - Class in org.infinispan.spring
An abstract base class for factories creating cache manager that are backed by an Infinispan RemoteCacheManager.
AbstractRemoteCacheManagerFactory() - Constructor for class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
AbstractStripedLockContainer<L extends Lock> - 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(String) - 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
 
AbstractTransport - Class in org.infinispan.remoting.transport
Common transport-related behaviour
AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
 
AbstractTransportConfigurationChildBuilder<T> - Class in org.infinispan.configuration.cache
 
AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
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
 
AbstractTxLockingInterceptor - Class in org.infinispan.interceptors.locking
Base class for transaction based locking interceptors.
AbstractTxLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
AbstractTypedPropertiesConfiguration - Class in org.infinispan.configuration
 
AbstractTypedPropertiesConfiguration(TypedProperties) - Constructor for class org.infinispan.configuration.AbstractTypedPropertiesConfiguration
 
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
 
AbstractWheelConsistentHash - Class in org.infinispan.distribution.ch
Abstract class for the wheel-based CH implementations.
AbstractWheelConsistentHash() - Constructor for class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
AbstractWheelConsistentHash.Externalizer<T extends AbstractWheelConsistentHash> - Class in org.infinispan.distribution.ch
 
AbstractWheelConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.ch.AbstractWheelConsistentHash.Externalizer
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.CustomInterceptorConfig
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.AdvancedExternalizersType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.GroupsConfiguration
 
accept(ConfigurationBeanVisitor) - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
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(File, String) - Method in class org.infinispan.loaders.file.FileCacheStore.NumericNamedFilesFilter
 
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.DistributedExecuteCommand
 
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.ApplyDeltaCommand
 
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.InvalidateL1Command
 
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.
acquireForCommand(InvocationContext, WriteCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireForCommand(TxInvocationContext, PrepareCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireForCommand(TxInvocationContext, CommitCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireForCommand(TxInvocationContext, RollbackCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireForCommand(TxInvocationContext, LockControlCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireForCommand(InvocationContext, WriteCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
acquireForCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
acquireForCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
acquireForCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
acquireForCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
acquireGlobalLock(boolean) - Method in class org.infinispan.loaders.LockSupportCacheStore
Based on the supplied param, acquires a global read(false) or write (true) lock.
acquireGlobalLock(boolean, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Acquires RL on all locks agregated by this StripedLock, in the given timeout.
acquireLock(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
acquireLock(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
acquireLock(Object, 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(InvocationContext, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
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, long) - Method in interface org.infinispan.util.concurrent.locks.LockManager
 
acquireLock(InvocationContext, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
acquireLock(InvocationContext, Object, long) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
acquireLock(Object, boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Blocks until a lock is acquired.
acquireLock(Object, boolean, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
acquireLockNoCheck(InvocationContext, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Same as LockManager.acquireLock(org.infinispan.context.InvocationContext, Object), but doesn't check whether the lock is already acquired by the caller.
acquireLockNoCheck(InvocationContext, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
acquireReadLock(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.
acquireReadLock(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.
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
doesn't do anything and returns true
acquireReadLock(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.
activated - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
activated - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.  
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.
adapt(Configuration) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(Configuration) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(GlobalConfiguration) - Static method in class org.infinispan.configuration.global.LegacyGlobalConfigurationAdaptor
 
adapt(GlobalConfiguration) - Static method in class org.infinispan.configuration.global.LegacyGlobalConfigurationAdaptor
 
AdaptiveBufferSizePredictor - Class in org.infinispan.marshall
The BufferSizePredictor that automatically increases and decreases the predicted buffer size on feed back.
AdaptiveBufferSizePredictor() - Constructor for class org.infinispan.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the default parameters.
AdaptiveBufferSizePredictor(int, int, int) - Constructor for class org.infinispan.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the specified parameters.
add(Object) - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
add(Object) - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
add(CommandInterceptor) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
add(CommandInterceptor) - Method in interface org.infinispan.config.FluentConfiguration.CustomInterceptorCumulator
Deprecated.  
add(Object) - Method in class org.infinispan.query.clustered.DistributedIterator
 
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 interface org.infinispan.remoting.ReplicationQueue
Adds a new command to the replication queue.
add(ReplicableCommand) - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
add(List<Xid>) - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
add(E) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
add(long) - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Adds the given value.
add(int, E) - Method in class org.infinispan.util.ForwardingList
 
add(E) - Method in class org.infinispan.util.ForwardingList
 
add(E) - Method in class org.infinispan.util.ImmutableListCopy
 
add(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
addAdvancedExternalizer(int, Class<? extends AdvancedExternalizer<T>>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Adds an AdvancedExternalizer with the give id.
addAdvancedExternalizer(Class<? extends AdvancedExternalizer<T>>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Adds an AdvancedExternalizer.
addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Helper method that allows for quick registration of an AdvancedExternalizer implementation alongside its corresponding identifier.
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Helper method that allows for quick registration of AdvancedExternalizer implementations.
addAdvancedExternalizer(Class<? extends AdvancedExternalizer<T>>) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
addAdvancedExternalizer(int, Class<? extends AdvancedExternalizer<T>>) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of an AdvancedExternalizer implementation alongside its corresponding identifier.
addAdvancedExternalizer(AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of an AdvancedExternalizer implementation alongside its corresponding identifier.
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of AdvancedExternalizer implementations.
addAffectedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAffectedKey(Object) - Method in interface org.infinispan.context.impl.TxInvocationContext
 
addAffectedKey(Object) - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
addAffectedKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
addAll(Collection<?>) - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
addAll(Collection<?>) - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
addAll(Collection<? extends E>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
addAll(int, Collection<? extends E>) - Method in class org.infinispan.util.ForwardingList
 
addAll(Collection<? extends E>) - Method in class org.infinispan.util.ForwardingList
 
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<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
addAllAffectedKeys(Collection<Object>) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAllAffectedKeys(Collection<Object>) - Method in interface org.infinispan.context.impl.TxInvocationContext
Registers a new participant with the transaction.
addAllAffectedKeys(Collection<Object>) - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
addAllAffectedKeys(Collection<Object>) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
addAttribute(XSAttributeDecl) - Method in class org.infinispan.tools.schema.TreeNode
 
addBackupLockForKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addCacheLoader(CacheLoaderConfig...) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
addCacheLoader(CacheLoaderConfig...) - Method in interface org.infinispan.config.FluentConfiguration.LoadersConfig
Deprecated.  
addCacheLoader() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
addCacheLoader(CacheLoader, CacheLoaderConfig) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
addCacheLoaderConfig(CacheLoaderConfig) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated. use CacheLoaderManagerConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...) instead
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
 
addCoinToss(DldGlobalTransaction) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
addEntry(InternalCacheEntry) - Method in class org.infinispan.loaders.bucket.Bucket
 
addErroneousAttribute(String) - Method in exception org.infinispan.CacheConfigurationException
 
addErroneousAttribute(String) - Method in exception org.infinispan.config.ConfigurationException
 
addFileCacheStore() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
addFlag(Flag) - Method in class org.infinispan.tree.TreeContext
 
addFlags(Flag[]) - Method in class org.infinispan.tree.TreeContext
 
addGrouper(Grouper<?>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Add a grouper
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.CacheImpl
 
addInterceptor() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Adds a new custom interceptor definition, to be added to the cache when the cache is started.
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.CacheImpl
 
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.CacheImpl
 
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.CacheImpl
 
addListener(Object) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
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.
addLocalTransactionMapping(LocalXaTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
addLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
Tracks the given key as locked by this invocation context.
addLockedKey(Object) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
addLockedKey(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
addModification(WriteCommand) - Method in class org.infinispan.transaction.LocalTransaction
 
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
 
addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addProperty(String, String) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
addProperty(String, String) - Method in interface org.infinispan.config.FluentConfiguration.DataContainerConfig
Deprecated.  
addProperty(String, String) - Method in interface org.infinispan.config.FluentConfiguration.IndexingConfig
Deprecated. Defines a single property.
addProperty(String, String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.ExecutorFactoryConfig
Deprecated. Add key/value property pair to this executor factory configuration
addProperty(String, String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated.  
addProperty(String, String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
addProperty(String, String) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Add key/value property pair to this data container configuration
addProperty(String, String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Defines a single property.
addProperty(String, String) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
Defines a single property.
addProperty(String, String) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addProperty(String, String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
addProperty(String, String) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addProperty(String, String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
addr - Variable in class org.infinispan.transaction.xa.GlobalTransaction
 
addReadKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
addReadKey(Object) - Method in class org.infinispan.transaction.LocalTransaction
 
addReadKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addRequestor(Object, Address) - Method in interface org.infinispan.distribution.L1Manager
Records a request that will be cached in another nodes L1
addRequestor(Object, Address) - Method in class org.infinispan.distribution.L1ManagerImpl
 
address - Variable in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
Address - Class in org.infinispan.nearcache.cdi
An address
Address() - Constructor for class org.infinispan.nearcache.cdi.Address
 
Address - Interface in org.infinispan.remoting.transport
A destination for an Infinispan command or operation.
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
AddressCache - Annotation Type in org.infinispan.nearcache.cdi
An address CDI qualifier
addressCache() - Method in class org.infinispan.nearcache.cdi.Config
 
AddressCacheManager - Class in org.infinispan.nearcache.cdi
Global operations for the address cache
AddressCacheManager() - Constructor for class org.infinispan.nearcache.cdi.AddressCacheManager
 
AddressController - Class in org.infinispan.nearcache.cdi
CDI controller
AddressController() - Constructor for class org.infinispan.nearcache.cdi.AddressController
 
AddressDao - Class in org.infinispan.nearcache.cdi
Address data access object
AddressDao() - Constructor for class org.infinispan.nearcache.cdi.AddressDao
 
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
 
addStatus(Set<Integer>) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
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
 
AdvancedCache<K,V> - Interface in org.infinispan
An advanced interface that exposes additional methods not available on Cache.
AdvancedCacheProducer - Class in org.infinispan.cdi
This class is responsible to produce the Cache and AdvancedCache.
AdvancedCacheProducer() - Constructor for class org.infinispan.cdi.AdvancedCacheProducer
 
AdvancedExternalizer<T> - Interface in org.infinispan.marshall
AdvancedExternalizer provides an alternative way to provide externalizers for marshalling/unmarshalling user defined classes that overcome the deficiencies of the more user-friendly externalizer definition model explained in Externalizer.
AdvancedExternalizerConfig - Class in org.infinispan.config
Defines custom Externalizers to be registered with marshalling framework
AdvancedExternalizerConfig() - Constructor for class org.infinispan.config.AdvancedExternalizerConfig
 
advancedExternalizers() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
affectedKeys - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
after(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.Configuration.CustomInterceptorPositionType
Deprecated.  
after - Variable in class org.infinispan.config.CustomInterceptorConfig
 
after(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.config.FluentConfiguration.CustomInterceptorPosition
Deprecated.  
after() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
after(Class<? extends CommandInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Dictates that the custom interceptor appears immediately after the specified interceptor.
afterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
afterCompletionFailed(Synchronization, Throwable) - Method in interface org.infinispan.util.logging.Log
 
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
afterInvocation() - Method in class org.infinispan.cdi.interceptor.literal.CachePutLiteral
 
afterInvocation() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveAllLiteral
 
afterInvocation() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveEntryLiteral
 
afterPropertiesSet() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
 
AggregatedParameterMetaData - Class in org.infinispan.cdi.interceptor.context.metadata
Contains all parameters metadata for a method annotated with a cache annotation.
AggregatedParameterMetaData(List<ParameterMetaData>, List<ParameterMetaData>, ParameterMetaData) - Constructor for class org.infinispan.cdi.interceptor.context.metadata.AggregatedParameterMetaData
 
AggregatingNotifyingFutureBuilder - Class in org.infinispan.util.concurrent
An aggregating NotifyingNotifiableFuture implementation that allows a dynamic number of futures to be attached.
AggregatingNotifyingFutureBuilder(Object, int) - Constructor for class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
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
 
all() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
all() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
Exhaust the iterator.
ALL_KNOWN_COMPONENT_NAMES - Static variable in class org.infinispan.factories.KnownComponentNames
 
allowDuplicateDomains(Boolean) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated. If true, multiple cache manager instances could be configured under the same configured JMX domain.
allowDuplicateDomains - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
allowDuplicateDomains(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
allowDuplicateDomains() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
allowDuplicateDomains(Boolean) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
If true, multiple cache manager instances could be configured under the same configured JMX domain.
allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
alwaysProvideInMemoryState - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
alwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
alwaysProvideInMemoryState(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. If true, this will allow the cache to provide in-memory state to a neighbor, even if the cache is not configured to fetch state from its neighbors (fetchInMemoryState is false)
alwaysProvideInMemoryStateDeprecated() - Method in interface org.infinispan.util.logging.Log
 
annotation(XSAnnotation) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
ApacheAvroMarshaller - Class in org.infinispan.client.hotrod.marshall
This is a portable serialization marshaller based on Apache Avro.
ApacheAvroMarshaller() - Constructor for class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
appendDelta(Delta) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
appendInterceptor(CommandInterceptor, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
Appends at the end.
applyClear() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
applyDelta(K, Delta, Object...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
applyDelta(K, Delta, Object...) - Method in interface org.infinispan.AdvancedCache
Applies the given Delta to the DeltaAware object stored under deltaAwareValueKey if and only if all locksToAcquire locks are successfully obtained
applyDelta(K, Delta, Object...) - Method in class org.infinispan.CacheImpl
 
ApplyDeltaCommand - Class in org.infinispan.commands.write
 
ApplyDeltaCommand() - Constructor for class org.infinispan.commands.write.ApplyDeltaCommand
 
ApplyDeltaCommand(Object, Delta, Collection<Object>) - Constructor for class org.infinispan.commands.write.ApplyDeltaCommand
 
applyLocks(Collection<LockInfo>, Address, int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
applyLocks(Collection<LockInfo>, Address, int) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
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.cassandra.CassandraCacheStore
 
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
Deprecated.  
applyOverridesTo(GlobalConfiguration) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory.GlobalConfigurationOverrides
 
applyOverridesTo(Configuration) - Method in class org.infinispan.spring.ConfigurationOverrides
 
applyState(Collection<InternalCacheEntry>, Address, int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
applyState(Collection<InternalCacheEntry>, Address, int) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
areNewTransactionsBlocked() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
areNewTransactionsBlocked() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
ARRAY_LIST - Static variable in interface org.infinispan.marshall.Ids
 
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) - Static method in class org.infinispan.batch.AutoBatchSupport
 
assertCorrectlyConfigured() - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
assertKeyNotNull(Object) - Static method in class org.infinispan.util.AbstractMap
 
assertNotNull(Object, String) - Static method in class org.infinispan.cdi.util.Contracts
Asserts that the given parameter is not null.
assertTypeConstructable(Class<?>, Class<?>...) - Method in class org.infinispan.factories.AbstractComponentFactory
 
assertValid(AtomicHashMap<?, ?>) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
assertValid() - Method in class org.infinispan.config.Configuration
Deprecated.  
asSet(T...) - Static method in class org.infinispan.cdi.util.CollectionsHelper
Creates a Set with the given elements.
asSet(T...) - Static method in class org.infinispan.util.Util
 
async - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
async() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
async() - Method in interface org.infinispan.config.FluentConfiguration.ClusteringConfig
Deprecated. Configure async sub element.
async() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
Configuration for the async cache loader.
async - Variable in class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
 
async() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
Configuration for the async cache loader.
async() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationChildBuilder
 
async() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Configure async sub element.
async() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Configure async sub element.
async() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
If configured all communications are asynchronous, in that whenever a thread sends a message sent over the wire, it does not wait for an acknowledgment before returning.
async() - Method in interface org.infinispan.configuration.cache.LoaderConfigurationChildBuilder
 
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
 
AsyncConfiguration - Class in org.infinispan.configuration.cache
If configured all communications are asynchronous, in that whenever a thread sends a message sent over the wire, it does not wait for an acknowledgment before returning.
AsyncConfigurationBuilder - Class in org.infinispan.configuration.cache
If configured all communications are asynchronous, in that whenever a thread sends a message sent over the wire, it does not wait for an acknowledgment before returning.
AsyncConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
asyncExecutor - Variable in class org.infinispan.query.backend.QueryInterceptor
 
asyncExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
asyncListenerExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
asyncListenerExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
asyncListenerExecutor() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
AsyncLoaderConfiguration - Class in org.infinispan.configuration.cache
Configuration for the async cache loader.
AsyncLoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration for the async cache loader.
asyncMarshalling - Variable in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
asyncMarshalling(Boolean) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
asyncMarshalling(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.AsyncConfig
Deprecated. If true, asynchronous marshalling is enabled which means that caller can return even quicker, but it can suffer from reordering of operations.
asyncMarshalling() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
Asynchronous marshalling allows the caller to return even quicker, but it can suffer from reordering of operations.
asyncMarshalling() - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
Enable asynchronous marshalling.
asyncProcessor - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
asyncStore() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
asyncStore() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
asyncStore() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
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
 
asyncStoreCoordinatorInterrupted(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in interface org.infinispan.util.logging.Log
 
asyncTransportExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
asyncTransportExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
asyncTransportExecutor() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
atIndex(int) - Method in class org.infinispan.config.Configuration.CustomInterceptorPositionType
Deprecated.  
atIndex(int) - Method in interface org.infinispan.config.FluentConfiguration.CustomInterceptorPosition
Deprecated.  
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
 
attachListener(FutureListener<T>) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
attachListener(FutureListener<V>) - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
attachListener(FutureListener<V>) - Method in class org.infinispan.util.concurrent.AbstractInProcessNotifyingFuture
 
attachListener(FutureListener<V>) - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
attachListener(FutureListener<E>) - Method in class org.infinispan.util.concurrent.NoOpFuture
 
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
 
attemptToLoadSameBucketIgnored(String) - Method in interface org.infinispan.loaders.cloud.logging.Log
 
attGroupDecl(XSAttGroupDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
Attribute - Enum in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
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
 
autoCommit(boolean) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
autoCommit - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
autoCommit(boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
autoCommit(boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated.  
autoCommit() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If the cache is transactional (i.e.
autoCommit(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If the cache is transactional (i.e.
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.distexec.DefaultExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 

B

backupKeyLocks - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
Base64 - Class in org.infinispan.util
Encodes and decodes to and from Base64 notation.
Base64.InputStream - Class in org.infinispan.util
A Base64.InputStream will read data from another java.io.InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.InputStream(InputStream) - Constructor for class org.infinispan.util.Base64.InputStream
Constructs a Base64.InputStream in DECODE mode.
Base64.InputStream(InputStream, int) - Constructor for class org.infinispan.util.Base64.InputStream
Constructs a Base64.InputStream in either ENCODE or DECODE mode.
Base64.OutputStream - Class in org.infinispan.util
A Base64.OutputStream will write data to another java.io.OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.OutputStream(OutputStream) - Constructor for class org.infinispan.util.Base64.OutputStream
Constructs a Base64.OutputStream in ENCODE mode.
Base64.OutputStream(OutputStream, int) - Constructor for class org.infinispan.util.Base64.OutputStream
Constructs a Base64.OutputStream in either ENCODE or DECODE mode.
baseCfg - Variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
BaseCustomInterceptor - Class in org.infinispan.interceptors.base
Anyone using the AdvancedCache.addInterceptor(CommandInterceptor, int) method (or any of its overloaded forms) or registering custom interceptors via XML should extend this base class when creating their own custom interceptors.
BaseCustomInterceptor() - Constructor for class org.infinispan.interceptors.base.BaseCustomInterceptor
 
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
 
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
 
BaseStateTransferManagerImpl - Class in org.infinispan.statetransfer
State transfer manager.
BaseStateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
BaseStateTransferTask - Class in org.infinispan.statetransfer
Push state from the existing members of the cluster to the new members.
BaseStateTransferTask(BaseStateTransferManagerImpl, RpcManager, StateTransferLock, CacheNotifier, Configuration, DataContainer, Collection<Address>, int, ConsistentHash, ConsistentHash, boolean) - Constructor for class org.infinispan.statetransfer.BaseStateTransferTask
 
BasicCache<K,V> - Interface in org.infinispan.api
BasicCache provides the common building block for the two different types of caches that Infinispan provides: embedded and remote.
BasicCacheContainer - Interface in org.infinispan.api
BasicCacheContainer defines the methods used to obtain a BasicCache.
BasicLogFactory - Class in org.infinispan.util.logging
Factory that creates Log instances.
BasicLogFactory() - Constructor for class org.infinispan.util.logging.BasicLogFactory
 
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.CacheImpl
 
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(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.Configuration.CustomInterceptorPositionType
Deprecated.  
before - Variable in class org.infinispan.config.CustomInterceptorConfig
 
before(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.config.FluentConfiguration.CustomInterceptorPosition
Deprecated.  
before() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
before(Class<? extends CommandInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Dictates that the custom interceptor appears immediately before the specified interceptor.
beforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
beforeCompletionFailed(Synchronization, Throwable) - Method in interface org.infinispan.util.logging.Log
 
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.
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
 
blockNewTransactions(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
blockNewTransactions(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
blockNewTransactionsAsync() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
blockNewTransactionsAsync() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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
 
broadcast(ClusteredQueryCommand) - Method in class org.infinispan.query.clustered.ClusteredQueryInvoker
Broadcast this ClusteredQueryCommand to all cluster nodes.
broadcastPrepare(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
broadcastPrepare(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.VersionedReplicationInterceptor
 
broadcastRemoteCommands(ReplicableCommand, ResponseMode, long, boolean, boolean, RspFilter, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
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
 
BufferSizePredictor - Interface in org.infinispan.marshall
Buffer size predictor
build() - Method in interface org.infinispan.config.FluentConfiguration.GroupsConfig
Deprecated.  
build() - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated.  
build() - Method in interface org.infinispan.config.FluentConfiguration.StoreAsBinaryConfig
Deprecated.  
build() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
build() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
build() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
Get back up to the CacheStoreConfig level.
build() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
buildApplyDeltaCommand(Object, Delta, Collection) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ApplyDeltaCommand used for applying Delta objects to DeltaAware containers stored in cache
buildApplyDeltaCommand(Object, Delta, Collection) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClearCommand(Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClearCommand
buildClearCommand(Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetCommand(Object, Set<Flag>, boolean, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command
buildClusteredGetCommand(Object, Set<Flag>, boolean, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCommandLineOptions() - Method in class org.infinispan.demo.Demo
 
buildCommandLineOptions() - Method in class org.infinispan.demo.distexec.PiApproximationDemo
 
buildCommandLineOptions() - Method in class org.infinispan.demo.mapreduce.WordCountDemo
 
buildCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CommitCommand
buildCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCompleteTransactionCommand(Xid, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CompleteTransactionCommand command.
buildCompleteTransactionCommand(Xid, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildDistributedExecuteCommand(Callable<T>, Address, Collection) - Method in interface org.infinispan.commands.CommandsFactory
Builds a DistributedExecuteCommand used for migration and execution of distributed Callables and Runnables.
buildDistributedExecuteCommand(Callable<T>, Address, Collection) - 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
 
buildGetInDoubtTransactionsCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetInDoubtTransactionsCommand.
buildGetInDoubtTransactionsCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetInDoubtTxInfoCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildGetInDoubtTxInfoCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetKeyValueCommand(Object, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
buildGetKeyValueCommand(Object, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInjectionMethodsList() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
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, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateFromL1Command
buildInvalidateFromL1Command(Address, boolean, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateFromL1Command(boolean, Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(boolean, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(Address, boolean, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildJmxDomain(GlobalConfiguration, MBeanServer, String) - Static method in class org.infinispan.jmx.JmxUtil
Build the JMX domain name.
buildKeySetCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a KeySetCommand
buildKeySetCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<Object>, Set<Flag>, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a LockControlCommand to control explicit remote locking
buildLockControlCommand(Object, Set<Flag>, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Same as CommandsFactory.buildLockControlCommand(Object, java.util.Set, org.infinispan.transaction.xa.GlobalTransaction) but for locking a single key vs a collection of keys.
buildLockControlCommand(Collection<Object>, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildLockControlCommand(Collection<Object>, Set<Flag>, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Object, Set<Flag>, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<Object>, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMapReduceCommand(Mapper, Reducer, Address, Collection) - Method in interface org.infinispan.commands.CommandsFactory
Builds a MapReduceCommand used for migration and execution of MapReduce tasks.
buildMapReduceCommand(Mapper, Reducer, Address, Collection) - 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
 
buildPrepareCommandForResend(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
buildPrepareCommandForResend(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
buildPrepareCommandForResend(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.VersionedDistributionInterceptor
 
buildPrepareCommandForResend(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.VersionedReplicationInterceptor
 
buildPutKeyValueCommand(Object, Object, long, long, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutKeyValueCommand
buildPutKeyValueCommand(Object, Object, long, long, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map<?, ?>, long, long, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutMapCommand
buildPutMapCommand(Map<?, ?>, long, long, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildQueryBuilderForClass(Class<?>) - Method in interface org.infinispan.query.SearchManager
Experimental.
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
 
buildRemoveCommand(Object, Object, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RemoveCommand
buildRemoveCommand(Object, Object, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplaceCommand(Object, Object, Object, long, long, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, long, long, Set<Flag>) - 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
 
buildStateTransferCommand(StateTransferControlCommand.Type, Address, int) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
buildStateTransferCommand(StateTransferControlCommand.Type, Address, int, Collection<InternalCacheEntry>, Collection<LockInfo>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RehashControlCommand for coordinating a rehash event.
buildStateTransferCommand(StateTransferControlCommand.Type, Address, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferCommand(StateTransferControlCommand.Type, Address, int, Collection<InternalCacheEntry>, Collection<LockInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(Xid, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a TxCompletionNotificationCommand.
buildTxCompletionNotificationCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxCompletionNotificationCommand(Xid, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(long) - 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
 
buildVersionedCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a VersionedCommitCommand
buildVersionedCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildVersionedPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a VersionedPrepareCommand
buildVersionedPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildVersionedPutKeyValueCommand(Object, Object, long, long, EntryVersion, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a special form of PutKeyValueCommand that also holds a reference to a version to be applied.
buildVersionedPutKeyValueCommand(Object, Object, long, long, EntryVersion, Set<Flag>) - 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(Codec, TransportFactory, byte[], AtomicInteger, Flag[], int) - Constructor for class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
ByRef<T> - Class in org.infinispan.util
This class can be used to pass an argument by reference.
ByRef(T) - Constructor for class org.infinispan.util.ByRef
 
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

cache - Variable in class org.infinispan.AbstractDelegatingAdvancedCache
 
cache - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
Cache<K,V> - Interface in org.infinispan
The central interface of Infinispan.
cache - Variable in class org.infinispan.distexec.DefaultExecutorService
 
cache - Variable in class org.infinispan.interceptors.base.BaseCustomInterceptor
 
cache - Variable in class org.infinispan.loaders.AbstractCacheLoader
 
cache - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
cache - Variable in class org.infinispan.query.impl.AbstractIterator
 
cache - Variable in class org.infinispan.query.impl.CacheQueryImpl
 
cache - Variable in class org.infinispan.tree.TreeStructureSupport
 
CACHE_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheJmxRegistration
 
CACHE_MANAGER_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheManagerJmxRegistration
 
CACHE_MANAGER_JMX_GROUP - Static variable in class org.infinispan.rhq.CacheManagerDiscovery
 
CACHE_MANAGER_OBJECTS - Static variable in class org.infinispan.rhq.CacheManagerDiscovery
 
CACHE_MARSHALLER - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_NAME - Static variable in interface org.infinispan.server.websocket.OpHandler
 
CACHE_RPC_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
CACHE_STOPPED_VIEW_ID - Static variable in class org.infinispan.transaction.TransactionTable
 
CACHE_VIEW - Static variable in interface org.infinispan.marshall.Ids
 
CacheBuilder - Class in org.infinispan.demo
Builds CacheManager given Infinispan configuration and transport file.
CacheBuilder(String) - Constructor for class org.infinispan.demo.CacheBuilder
 
CacheBuilder - Class in org.infinispan.ec2demo
 
CacheBuilder(String) - Constructor for class org.infinispan.ec2demo.CacheBuilder
 
cacheCanNotHandleInvocations(String) - Method in interface org.infinispan.util.logging.Log
 
CacheComponent - Class in org.infinispan.rhq
Component class for Caches within Infinispan
CacheComponent() - Constructor for class org.infinispan.rhq.CacheComponent
 
cacheComponentPattern(String, String) - Static method in class org.infinispan.rhq.CacheDiscovery
 
cacheConfigurationDefined(String, EmbeddedCacheManager) - Method in interface org.infinispan.cdi.util.logging.Log
 
CacheConfigurationException - Exception in org.infinispan
An exception that represents an error in the configuration.
CacheConfigurationException(Exception) - Constructor for exception org.infinispan.CacheConfigurationException
 
CacheConfigurationException(String) - Constructor for exception org.infinispan.CacheConfigurationException
 
CacheConfigurationException(String, String) - Constructor for exception org.infinispan.CacheConfigurationException
 
CacheConfigurationException(String, Throwable) - Constructor for exception org.infinispan.CacheConfigurationException
 
cacheContainer - Static variable in class org.infinispan.demos.gridfs.CacheManagerHolder
 
CacheContainer - Interface in org.infinispan.manager
 
CacheDiscovery - Class in org.infinispan.rhq
Discovery class for individual cache instances
CacheDiscovery() - Constructor for class org.infinispan.rhq.CacheDiscovery
 
CacheEntriesEvicted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when cache entries are evicted.
CacheEntriesEvictedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntriesEvicted.
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.
CacheEntryActivatedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryActivatedAdapter(Event<CacheEntryActivatedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryActivatedAdapter
 
CacheEntryActivatedEvent<K,V> - 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<Object, Object>) - Method in class org.infinispan.server.websocket.CacheListener
 
CacheEntryCreatedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryCreatedAdapter(Event<CacheEntryCreatedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryCreatedAdapter
 
CacheEntryCreatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryCreated.
CacheEntryEvent<K,V> - 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
Deprecated. Note that this annotation will be removed in Infinispan 6.0
CacheEntryEvictedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryEvictedAdapter(Event<CacheEntryEvictedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryEvictedAdapter
 
CacheEntryEvictedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
Deprecated. Note that this interface will be removed in Infinispan 6.0
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.
CacheEntryInvalidatedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryInvalidatedAdapter(Event<CacheEntryInvalidatedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryInvalidatedAdapter
 
CacheEntryInvalidatedEvent<K,V> - 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.
CacheEntryLoadedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryLoadedAdapter(Event<CacheEntryLoadedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryLoadedAdapter
 
CacheEntryLoadedEvent<K,V> - 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<Object, Object>) - Method in class org.infinispan.server.websocket.CacheListener
 
CacheEntryModifiedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryModifiedAdapter(Event<CacheEntryModifiedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryModifiedAdapter
 
CacheEntryModifiedEvent<K,V> - 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 cache entries are passivated.
CacheEntryPassivatedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryPassivatedAdapter(Event<CacheEntryPassivatedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryPassivatedAdapter
 
CacheEntryPassivatedEvent<K,V> - 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<Object, Object>) - Method in class org.infinispan.server.websocket.CacheListener
 
CacheEntryRemovedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryRemovedAdapter(Event<CacheEntryRemovedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryRemovedAdapter
 
CacheEntryRemovedEvent<K,V> - 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.
CacheEntryVisitedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
CacheEntryVisitedAdapter(Event<CacheEntryVisitedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.CacheEntryVisitedAdapter
 
CacheEntryVisitedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryVisited.
CacheEventBridge - Class in org.infinispan.cdi.event.cache
 
CacheEventBridge() - Constructor for class org.infinispan.cdi.event.cache.CacheEventBridge
 
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
 
cacheExists(String) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
cacheExists(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
cacheExists(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
A cache is considered to exist if it has been created and started via one of the CacheContainer.getCache() methods and has not yet been removed via EmbeddedCacheManager.removeCache(String).
cacheForWriting - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
CacheImpl<K,V> - Class in org.infinispan
 
CacheImpl(String) - Constructor for class org.infinispan.CacheImpl
 
CacheInvocationParameterImpl - Class in org.infinispan.cdi.interceptor.context
The CacheInvocationParameter implementation.
CacheInvocationParameterImpl(ParameterMetaData, Object) - Constructor for class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
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
 
cacheKeyGenerator() - Method in class org.infinispan.cdi.interceptor.literal.CachePutLiteral
 
cacheKeyGenerator() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveEntryLiteral
 
cacheKeyGenerator() - Method in class org.infinispan.cdi.interceptor.literal.CacheResultLiteral
 
CacheKeyInvocationContextFactory - Class in org.infinispan.cdi.interceptor.context
 
CacheKeyInvocationContextFactory(BeanManager) - Constructor for class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextFactory
 
CacheKeyInvocationContextFactory() - Constructor for class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextFactory
 
CacheKeyInvocationContextImpl<A extends Annotation> - Class in org.infinispan.cdi.interceptor.context
The CacheKeyInvocationContext implementation.
CacheKeyInvocationContextImpl(InvocationContext, MethodMetaData<A>) - Constructor for class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
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() - Method in class org.infinispan.configuration.cache.LoaderConfiguration
 
cacheLoader(CacheLoader) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
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
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in interface org.infinispan.util.logging.Log
 
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
cacheLoaderManager - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
CacheLoaderManagerConfig - Class in org.infinispan.config
Holds the configuration of the cache loader chain.
CacheLoaderManagerConfig() - Constructor for class org.infinispan.config.CacheLoaderManagerConfig
 
CacheLoaderManagerConfig(CacheLoaderConfig) - 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.
cacheLoaders() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
CacheLookupHelper - Class in org.infinispan.cdi.util
An helper class providing useful methods for cache lookup.
CacheManager - Interface in org.infinispan.manager
Deprecated. 
cacheManagerAlreadyRegistered(String) - Method in interface org.infinispan.util.logging.Log
 
CacheManagerComponent - Class in org.infinispan.rhq
The component class for the Infinispan manager
CacheManagerComponent() - Constructor for class org.infinispan.rhq.CacheManagerComponent
 
CacheManagerDiscovery - Class in org.infinispan.rhq
Discovery class for Infinispan engines
CacheManagerDiscovery() - Constructor for class org.infinispan.rhq.CacheManagerDiscovery
 
CacheManagerEventBridge - Class in org.infinispan.cdi.event.cachemanager
 
CacheManagerEventBridge() - Constructor for class org.infinispan.cdi.event.cachemanager.CacheManagerEventBridge
 
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
 
cacheManagerName(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated. If JMX statistics are enabled, this property represents the name of this cache manager.
cacheManagerName - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
cacheManagerName(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
cacheManagerName() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
If JMX statistics are enabled, this property represents the name of this cache manager.
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, GlobalConfiguration) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lucene.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.tree.LifecycleCallbacks
 
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
 
CacheMarshaller - Class in org.infinispan.marshall
A cache-scoped marshaller.
CacheMarshaller(VersionAwareMarshaller) - Constructor for class org.infinispan.marshall.CacheMarshaller
 
CacheMembershipManagerFactory - Class in org.infinispan.factories
Constructs CacheViewsManager instances.
CacheMembershipManagerFactory() - Constructor for class org.infinispan.factories.CacheMembershipManagerFactory
 
CacheMgmtInterceptor - Class in org.infinispan.interceptors
Captures cache management statistics
CacheMgmtInterceptor() - Constructor for class org.infinispan.interceptors.CacheMgmtInterceptor
 
CacheMode - Enum in org.infinispan.configuration.cache
Cache replication mode.
cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Cache mode.
cacheMode(CacheMode) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Cache mode.
cacheModeString() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
cacheName() - Method in class org.infinispan.cdi.interceptor.literal.CachePutLiteral
 
cacheName() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveAllLiteral
 
cacheName() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveEntryLiteral
 
cacheName() - Method in class org.infinispan.cdi.interceptor.literal.CacheResultLiteral
 
cacheName - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
cacheName(byte[]) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
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.
cacheNotifier - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
cacheNotifier - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
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
 
cacheNotStarted() - Method in interface org.infinispan.util.logging.Log
 
cachePut(InvocationContext) - Method in class org.infinispan.cdi.interceptor.CachePutInterceptor
 
CachePutInterceptor - Class in org.infinispan.cdi.interceptor
CachePut interceptor implementation.
CachePutInterceptor(CacheResolver, CacheKeyInvocationContextFactory) - Constructor for class org.infinispan.cdi.interceptor.CachePutInterceptor
 
CachePutLiteral - Class in org.infinispan.cdi.interceptor.literal
 
cachePutMethodWithMoreThanOneCacheValueParameter(String) - Method in interface org.infinispan.cdi.util.logging.Log
 
cachePutMethodWithoutCacheValueParameter(String) - Method in interface org.infinispan.cdi.util.logging.Log
 
CacheQuery - Interface in org.infinispan.query
A cache-query is what will be returned when the getQuery() method is run on SearchManagerImpl.
CacheQueryImpl - Class in org.infinispan.query.impl
Implementation class of the CacheQuery interface.
CacheQueryImpl(Query, SearchFactoryIntegrator, AdvancedCache<?, ?>, KeyTransformationHandler, Class<?>...) - Constructor for class org.infinispan.query.impl.CacheQueryImpl
 
cacheRemoveAll(InvocationContext) - Method in class org.infinispan.cdi.interceptor.CacheRemoveAllInterceptor
 
CacheRemoveAllInterceptor - Class in org.infinispan.cdi.interceptor
CacheRemoveAll interceptor implementation.
CacheRemoveAllInterceptor(CacheResolver, CacheKeyInvocationContextFactory) - Constructor for class org.infinispan.cdi.interceptor.CacheRemoveAllInterceptor
 
CacheRemoveAllLiteral - Class in org.infinispan.cdi.interceptor.literal
 
cacheRemoveAllMethodWithoutCacheName(String) - Method in interface org.infinispan.cdi.util.logging.Log
 
cacheRemoveEntry(InvocationContext) - Method in class org.infinispan.cdi.interceptor.CacheRemoveEntryInterceptor
 
CacheRemoveEntryInterceptor - Class in org.infinispan.cdi.interceptor
CacheRemoveEntry interceptor implementation.This interceptor uses the following algorithm describes in JSR-107.
CacheRemoveEntryInterceptor(CacheResolver, CacheKeyInvocationContextFactory) - Constructor for class org.infinispan.cdi.interceptor.CacheRemoveEntryInterceptor
 
CacheRemoveEntryLiteral - Class in org.infinispan.cdi.interceptor.literal
 
cacheRemoveEntryMethodWithoutCacheName(String) - Method in interface org.infinispan.cdi.util.logging.Log
 
CacheResolver - Interface in org.infinispan.cdi.interceptor
This is the cache resolver contract used by interceptors to resolve a Cache.
cacheResolverFactory() - Method in class org.infinispan.cdi.interceptor.literal.CachePutLiteral
 
cacheResolverFactory() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveAllLiteral
 
cacheResolverFactory() - Method in class org.infinispan.cdi.interceptor.literal.CacheRemoveEntryLiteral
 
cacheResolverFactory() - Method in class org.infinispan.cdi.interceptor.literal.CacheResultLiteral
 
cacheResult(InvocationContext) - Method in class org.infinispan.cdi.interceptor.CacheResultInterceptor
 
CacheResultInterceptor - Class in org.infinispan.cdi.interceptor
CacheResult interceptor implementation.
CacheResultInterceptor(CacheResolver, CacheKeyInvocationContextFactory) - Constructor for class org.infinispan.cdi.interceptor.CacheResultInterceptor
 
CacheResultLiteral - Class in org.infinispan.cdi.interceptor.literal
 
CacheRpcCommand - Interface in org.infinispan.commands.remote
The RpcManager only replicates commands wrapped in a CacheRpcCommand.
CacheRpcCommandExternalizer - Class in org.infinispan.marshall.exts
Externalizer in charge of marshalling cache specific commands.
CacheRpcCommandExternalizer(GlobalComponentRegistry, ReplicableCommandExternalizer) - Constructor for class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
caches - Variable in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
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
 
CacheStartedAdapter - Class in org.infinispan.cdi.event.cachemanager
 
CacheStartedAdapter(Event<CacheStartedEvent>, String) - Constructor for class org.infinispan.cdi.event.cachemanager.CacheStartedAdapter
 
CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStarted.
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.query.impl.LifecycleManager
Registers the Search interceptor in the cache before it gets started
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
 
CacheStoppedAdapter - Class in org.infinispan.cdi.event.cachemanager
 
CacheStoppedAdapter(Event<CacheStoppedEvent>, String) - Constructor for class org.infinispan.cdi.event.cachemanager.CacheStoppedAdapter
 
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
 
cacheStopping(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
cacheStopTimeout - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
cacheStopTimeout(Integer) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
cacheStopTimeout(Integer) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStopTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStopTimeout() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStopTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
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, int) - 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.
cacheValue - Variable in class org.infinispan.container.entries.ImmortalCacheEntry
 
cacheValue - Variable in class org.infinispan.container.entries.MortalCacheEntry
 
cacheValue - Variable in class org.infinispan.container.entries.TransientCacheEntry
 
cacheValue - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
CacheView - Class in org.infinispan.cacheviews
A virtual view for a cache.
CacheView(int, List<Address>) - Constructor for class org.infinispan.cacheviews.CacheView
 
CacheView.Externalizer - Class in org.infinispan.cacheviews
 
CacheView.Externalizer() - Constructor for class org.infinispan.cacheviews.CacheView.Externalizer
 
cacheViewCommitFailure(Throwable, int, String) - Method in interface org.infinispan.util.logging.Log
 
CacheViewControlCommand - Class in org.infinispan.commands.control
A control command to coordinate the installation of cache views between the members of the cluster.
CacheViewControlCommand() - Constructor for class org.infinispan.commands.control.CacheViewControlCommand
 
CacheViewControlCommand(String) - Constructor for class org.infinispan.commands.control.CacheViewControlCommand
 
CacheViewControlCommand(String, CacheViewControlCommand.Type, Address, int, List<Address>, int, List<Address>) - Constructor for class org.infinispan.commands.control.CacheViewControlCommand
 
CacheViewControlCommand(String, CacheViewControlCommand.Type, Address, int) - Constructor for class org.infinispan.commands.control.CacheViewControlCommand
 
CacheViewControlCommand(String, CacheViewControlCommand.Type, Address) - Constructor for class org.infinispan.commands.control.CacheViewControlCommand
 
CacheViewControlCommand.Type - Enum in org.infinispan.commands.control
 
CacheViewInfo - Class in org.infinispan.cacheviews
The cluster-wide state of a cache.
CacheViewInfo(String, CacheView) - Constructor for class org.infinispan.cacheviews.CacheViewInfo
 
CacheViewListener - Interface in org.infinispan.cacheviews
Callback interface for installing views on a cache.
cacheViewPrepareFailure(Throwable, CacheView, String, CacheView) - Method in interface org.infinispan.util.logging.Log
 
cacheViewRollbackFailure(Throwable, int, String) - Method in interface org.infinispan.util.logging.Log
 
cacheViewRollbackIdMismatch(int, int) - Method in interface org.infinispan.util.logging.Log
 
CacheViewsManager - Interface in org.infinispan.cacheviews
A component that manages a virtual view of the cluster for each defined cache.
CacheViewsManagerImpl - Class in org.infinispan.cacheviews
CacheViewsManager implementation.
CacheViewsManagerImpl() - Constructor for class org.infinispan.cacheviews.CacheViewsManagerImpl
 
CacheViewsManagerImpl.ViewInstallationTask - Class in org.infinispan.cacheviews
Executed on the coordinator to install a new view in the cluster.
CacheViewsManagerImpl.ViewInstallationTask(String, CacheView) - Constructor for class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewInstallationTask
 
CacheViewsManagerImpl.ViewListener - Class in org.infinispan.cacheviews
 
CacheViewsManagerImpl.ViewListener() - Constructor for class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewListener
 
CacheViewsManagerImpl.ViewTriggerThread - Class in org.infinispan.cacheviews
Executed on the coordinator to trigger the installation of new views.
CacheViewsManagerImpl.ViewTriggerThread() - Constructor for class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewTriggerThread
 
calculateHashCode() - Method in class org.infinispan.tree.Fqn
Calculates a hash code by summing the hash code of all elements.
calculateRank(Address, List<Address>, long) - Method in class org.infinispan.util.ClusterIdGenerator
 
calculateRank(ViewChangedEvent) - Method in class org.infinispan.util.ClusterIdGenerator.RankCalculator
 
call() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewInstallationTask
 
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.distexec.DefaultExecutorService.DistributedRunnableFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.NoOpFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
cancelStateTransfer(boolean) - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
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
 
cannotSelectRandomMembers(int, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
CassandraCacheStore - Class in org.infinispan.loaders.cassandra
A persistent CacheLoader based on Apache Cassandra project.
CassandraCacheStore() - Constructor for class org.infinispan.loaders.cassandra.CassandraCacheStore
 
CassandraCacheStoreConfig - Class in org.infinispan.loaders.cassandra
Configures CassandraCacheStore.
CassandraCacheStoreConfig() - Constructor for class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
cf - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
cfgFile - Variable in class org.infinispan.demo.Demo
 
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
 
channelConnectedLatch - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channelNotSetUp() - Method in interface org.infinispan.util.logging.Log
 
channelStillBound(Channel, SocketAddress) - Method in interface org.infinispan.server.core.logging.JavaLog
 
channelStillConnected(Channel, SocketAddress) - Method in interface org.infinispan.server.core.logging.JavaLog
 
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
 
checkIfCancelled() - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
checkParentDirs(String, boolean) - Method in class org.infinispan.io.GridFile
Checks whether the parent directories are present (and are directories).
checkResponse(Object, Address) - Method in class org.infinispan.remoting.transport.AbstractTransport
 
checkStatisticsUsed() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
chNew - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
chNew - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
chOld - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
chOld - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
CHUNK_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
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
 
ChunkCacheKey.Externalizer - Class in org.infinispan.lucene
 
ChunkCacheKey.Externalizer() - Constructor for class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
chunkSize - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
chunkSize(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
chunkSize(Integer) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. Size of a state transfer chunk, in cache entries.
chunkSize() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
If > 0, the state will be transferred in batches of chunkSize cache entries.
chunkSize(int) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
If > 0, the state will be transferred in batches of chunkSize cache entries.
CLASS_LOADER - Static variable in class org.infinispan.factories.KnownComponentNames
 
ClassFinder - Class in org.infinispan.util
Find infinispan classes utility
ClassFinder() - Constructor for class org.infinispan.util.ClassFinder
 
classLoader() - Method in class org.infinispan.configuration.cache.Configuration
Deprecated. 
classLoader(ClassLoader) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
classLoader() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Get the classloader in use by this configuration.
classLoader(ClassLoader) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
ClassLoaderSpecfiedCache<K,V> - Class in org.infinispan
 
ClassLoaderSpecfiedCache(AdvancedCache<K, V>, ClassLoader) - Constructor for class org.infinispan.ClassLoaderSpecfiedCache
 
className - Variable in class org.infinispan.config.CustomInterceptorConfig
 
className - Variable in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
classNotFoundIntegratingState(ClassNotFoundException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
classResolver(ClassResolver) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Class resolver to use when unmarshallig objects.
classResolver(ClassResolver) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
classResolver() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
classResolver(ClassResolver) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Class resolver to use when unmarshallig objects.
cleanLocksAndRethrow(InvocationContext, Throwable) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
cleanup() - Static method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
cleanupTaskFrequency(Long) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
cleanupTaskFrequency(Long) - Method in interface org.infinispan.config.FluentConfiguration.L1Config
Deprecated. Determines how often a cleanup thread runs to clean up an internal log of requestors for a specific key
cleanupTaskFrequency() - Method in class org.infinispan.configuration.cache.L1Configuration
Determines how often a cleanup thread runs to clean up an internal log of requestors for a specific key
cleanupTaskFrequency(long) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
How often the L1 requestors map is cleaned up of stale items
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.atomic.FineGrainedAtomicHashMapProxy
 
clear() - Method in class org.infinispan.CacheImpl
 
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 class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
clear() - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
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.DecoratedCache
 
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.cassandra.CassandraCacheStore
 
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.marshall.MarshallableTypeHints
Clear the cached marshallable type hints.
clear() - Method in class org.infinispan.spring.provider.SpringCache
 
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.concurrent.ConcurrentWeakKeyHashMap
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Removes all of the mappings from this map.
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.ForwardingList
 
clear() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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.api.BasicCache
Asynchronous version of Map.clear().
clearAsync() - Method in class org.infinispan.CacheImpl
 
clearAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clearAsync() - Method in class org.infinispan.DecoratedCache
 
clearCache() - Method in class org.infinispan.nearcache.cdi.AddressCacheManager
 
clearCacheLoaders() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
clearCacheStore() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
ClearCommand - Class in org.infinispan.commands.write
 
ClearCommand() - Constructor for class org.infinispan.commands.write.ClearCommand
 
ClearCommand(CacheNotifier, Set<Flag>) - 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
 
clearData(AdvancedCache<NodeKey, AtomicMap<?, ?>>, Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
clearEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
clearGroupers() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Clear the groupers
clearLock(String) - Method in class org.infinispan.lucene.locking.BaseLockFactory
clearLock(String) - Method in class org.infinispan.lucene.locking.TransactionalLockFactory
clearLockedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.ImmutableContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clearLockedKeys() - Method in interface org.infinispan.context.InvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
clearLockedKeys() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
clearLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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.ImmutableContext
 
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 class org.infinispan.context.InvocationContextFlagsOverride
 
clearLookedUpEntries() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
clearLookedUpEntries() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
clearLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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(Codec, 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
 
clearProperties() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Clears the transport properties
clearRemoteLocksAcquired() - Method in class org.infinispan.transaction.LocalTransaction
 
clearThreadLocal() - Method in class org.infinispan.context.AbstractInvocationContextContainer
 
clearThreadLocal() - Method in interface org.infinispan.context.InvocationContextContainer
Must be called as each thread exists the interceptor chain.
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
 
clientIntel(byte) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
cll - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
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
Deprecated.  
clone() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
clone() - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
clone() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
clone() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
clone() - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
clone() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
clone() - Method in class org.infinispan.config.CustomInterceptorConfig
 
clone() - Method in class org.infinispan.config.GlobalConfiguration.AdvancedExternalizersType
Deprecated.  
clone() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
clone() - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
clone() - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
clone() - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
clone() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
clone() - Method in class org.infinispan.config.GroupsConfiguration
 
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.ImmutableContext
 
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
Clones the invocation context.
clone() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
clone(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
clone(Mapper<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
clone(Reducer<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
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.AbstractDecoratorConfigurationBean
 
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.RemoteTransaction
 
clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
clone() - Method in class org.infinispan.util.FastCopyHashMap
 
CloneableConfigurationComponent - Interface in org.infinispan.config
Interface for all configurable components
cloneWithMarshaller(Marshaller, T) - Static method in class org.infinispan.util.Util
Clones parameter x of type T with a given Marshaller reference;
close() - Method in class org.infinispan.io.GridInputStream
 
close() - Method in class org.infinispan.io.GridOutputStream
 
close() - Method in class org.infinispan.io.ReadableGridFileChannel
 
close() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
close() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
close() - Method in class org.infinispan.io.WritableGridFileChannel
 
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.clustered.DistributedIterator
 
close() - Method in class org.infinispan.query.clustered.DistributedLazyIterator
 
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.Base64.OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
close(InputStream) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an InputStream.
close(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an OutputStream.
close(Object) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an InputStream or OutputStream.
close(InputStream[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an array of InputStreams.
close(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an array of OutputStreams.
close(Object[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an array of InputStreama and/or OutputStreams.
close(Closeable) - Static method in class org.infinispan.util.Util
 
close(Socket) - Static method in class org.infinispan.util.Util
 
close(Closeable...) - Static method in class org.infinispan.util.Util
 
close(Context) - Static method in class org.infinispan.util.Util
 
closeMarshaller() - Method in interface org.infinispan.marshall.jboss.RiverCloseListener
 
closeUnmarshaller() - Method in interface org.infinispan.marshall.jboss.RiverCloseListener
 
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 - Variable in class org.infinispan.transaction.TransactionTable
 
CLUSTERED_QUERY - Static variable in interface org.infinispan.query.ModuleCommandIds
 
ClusteredActivationInterceptor - Class in org.infinispan.interceptors
The same as a regular cache loader interceptor, except that it contains additional logic to force loading from the cache loader if needed on a remote node, in certain conditions.
ClusteredActivationInterceptor() - Constructor for class org.infinispan.interceptors.ClusteredActivationInterceptor
 
ClusteredCacheLoaderInterceptor - Class in org.infinispan.interceptors
The same as a regular cache loader interceptor, except that it contains additional logic to force loading from the cache loader if needed on a remote node, in certain conditions.
ClusteredCacheLoaderInterceptor() - Constructor for class org.infinispan.interceptors.ClusteredCacheLoaderInterceptor
 
ClusteredCacheQueryImpl - Class in org.infinispan.query.clustered
A extension of CacheQueryImpl used for distributed queries.
ClusteredCacheQueryImpl(Query, SearchFactoryIntegrator, ExecutorService, AdvancedCache<?, ?>, KeyTransformationHandler, Class<?>...) - Constructor for class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
clusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
ClusteredDoc - Interface in org.infinispan.query.clustered
ClusteredDoc.
ClusteredFieldDoc - Class in org.infinispan.query.clustered
ClusteredFIeldDoc.
ClusteredFieldDoc(FieldDoc, UUID, int) - Constructor for class org.infinispan.query.clustered.ClusteredFieldDoc
 
ClusteredGetCommand - Class in org.infinispan.commands.remote
Issues a remote get call.
ClusteredGetCommand(String) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetCommand(Object, String, Set<Flag>, boolean, GlobalTransaction) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetCommand(Object, String) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetCommand(String, String, Set<Flag>) - 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>, Address) - Constructor for class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
ClusteredQueryCommand - Class in org.infinispan.query.clustered
Encapsulates all rpc calls for distributed queries actions
ClusteredQueryCommand(String) - Constructor for class org.infinispan.query.clustered.ClusteredQueryCommand
For CommandFactory only.
ClusteredQueryCommandType - Enum in org.infinispan.query.clustered
Types of ClusteredQueryCommandWorker.
ClusteredQueryCommandWorker - Class in org.infinispan.query.clustered.commandworkers
ClusteredQueryCommandWorker.
ClusteredQueryCommandWorker() - Constructor for class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
ClusteredQueryInvoker - Class in org.infinispan.query.clustered
Invoke a CusteredQueryCommand on the cluster, including on own node.
ClusteredRepeatableReadEntry - Class in org.infinispan.container.entries
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
ClusteredRepeatableReadEntry(Object, Object, EntryVersion, long) - Constructor for class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
ClusteredScoreDoc - Class in org.infinispan.query.clustered
ClusteredScoreDoc.
ClusteredScoreDoc(ScoreDoc, UUID, int) - Constructor for class org.infinispan.query.clustered.ClusteredScoreDoc
 
ClusteredTopDocs - Class in org.infinispan.query.clustered
ClusteredTopDocs.
ClusterIdGenerator - Class in org.infinispan.util
This class generates ids guaranteed to be unique cluster wide.
ClusterIdGenerator(EmbeddedCacheManager, Transport) - Constructor for class org.infinispan.util.ClusterIdGenerator
 
ClusterIdGenerator.RankCalculator - Class in org.infinispan.util
 
ClusterIdGenerator.RankCalculator() - Constructor for class org.infinispan.util.ClusterIdGenerator.RankCalculator
 
clustering() - Method in class org.infinispan.configuration.cache.Configuration
 
clustering() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
clustering() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
ClusteringConfiguration - Class in org.infinispan.configuration.cache
Defines clustered characteristics of the cache.
ClusteringConfigurationBuilder - Class in org.infinispan.configuration.cache
Defines clustered characteristics of the cache.
ClusteringConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ClusteringDependentLogic - Interface in org.infinispan.interceptors.locking
Abstractization for logic related to different clustering modes: replicated or distributed.
ClusteringDependentLogic.AllNodesLogic - Class in org.infinispan.interceptors.locking
This logic is used when a changing a key affects all the nodes in the cluster, e.g.
ClusteringDependentLogic.AllNodesLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
ClusteringDependentLogic.DistributionLogic - Class in org.infinispan.interceptors.locking
 
ClusteringDependentLogic.DistributionLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
clusteringLogic - Variable in class org.infinispan.transaction.TransactionTable
 
clusterName(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. Defines the name of the cluster.
clusterName - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
clusterName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
clusterName() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
clusterName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Defines the name of the cluster.
cm - Variable in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
codec - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
Codec - Interface in org.infinispan.client.hotrod.impl.protocol
A Hot Rod protocol encoder/decoder.
Codec10 - Class in org.infinispan.client.hotrod.impl.protocol
A Hot Rod encoder/decoder for version 1.0 of the protocol.
Codec10() - Constructor for class org.infinispan.client.hotrod.impl.protocol.Codec10
 
Codec11 - Class in org.infinispan.client.hotrod.impl.protocol
A Hot Rod encoder/decoder for version 1.1 of the protocol.
Codec11() - Constructor for class org.infinispan.client.hotrod.impl.protocol.Codec11
 
CodecFactory - Class in org.infinispan.client.hotrod.impl.protocol
Code factory.
CodecFactory() - Constructor for class org.infinispan.client.hotrod.impl.protocol.CodecFactory
 
CODENAME - Static variable in class org.infinispan.Version
 
coinToss - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
collate(Map<String, Integer>) - Method in class org.infinispan.demo.mapreduce.WordCountCollator
 
collate(Map<KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.Collator
Collates all reduced results and returns R to invoker of distributed task.
Collator<KOut,VOut,R> - Interface in org.infinispan.distexec.mapreduce
Collator collates results from Reducers executed on Infinispan cluster and assembles a final result returned to an invoker of MapReduceTask.
CollectionsHelper - Class in org.infinispan.cdi.util
An helper class providing useful methods to work with JDK collections.
Collector<K,V> - Interface in org.infinispan.distexec.mapreduce
OutputCollector is the intermediate key/value result data output collector given to each Mapper
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.CacheViewControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.control.LockControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.control.StateTransferControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.DistributedExecuteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.MapReduceCommand
 
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.recovery.CompleteTransactionCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.SingleRpcCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.RemoveCacheCommand
 
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.tx.VersionedCommitCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.VersionedPrepareCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ApplyDeltaCommand
 
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_ID - Static variable in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.query.clustered.ClusteredQueryCommand
 
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(Channel, JGroupsTransport, ExecutorService, InboundInvocationHandler) - Constructor for class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
CommandFactory - Class in org.infinispan.query
Remote commands factory implementation
CommandFactory() - Constructor for class org.infinispan.query.CommandFactory
 
CommandInitializer - Class in org.infinispan.query
Initializes query module remote commands
CommandInitializer() - Constructor for class org.infinispan.query.CommandInitializer
 
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
 
commandLineOptions - Variable in class org.infinispan.demo.Demo
 
commandsFactory - Variable in class org.infinispan.CacheImpl
 
CommandsFactory - Interface in org.infinispan.commands
A factory to build commands, initializing and injecting dependencies accordingly.
commandsFactory - Variable in class org.infinispan.transaction.TransactionTable
 
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, EntryVersion) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
commit(DataContainer, EntryVersion) - Method in interface org.infinispan.container.entries.CacheEntry
Commits changes
commit(DataContainer, EntryVersion) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
commit(DataContainer, EntryVersion) - 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() - 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(LocalTransaction, boolean) - Method in class org.infinispan.transaction.TransactionCoordinator
 
commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
Same comment as for TransactionXaAdapter.prepare(javax.transaction.xa.Xid) applies for commit.
CommitCommand - Class in org.infinispan.commands.tx
Command corresponding to the 2nd phase of 2PC.
CommitCommand(String, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.CommitCommand
 
CommitCommand(String) - Constructor for class org.infinispan.commands.tx.CommitCommand
 
commitCommand(TxInvocationContext) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
commitContextEntries(InvocationContext) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, boolean) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, boolean) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
commitEntry(CacheEntry, EntryVersion, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
commitEntry(CacheEntry, EntryVersion, boolean) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
commitEntry(CacheEntry, EntryVersion, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
commitStateTransfer() - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
commitStateTransfer() - Method in class org.infinispan.statetransfer.DistributedStateTransferTask
 
commitView(int) - Method in class org.infinispan.cacheviews.CacheViewInfo
Update the committed view
commitView(int) - Method in interface org.infinispan.cacheviews.CacheViewListener
Called before committing a cache view.
commitView(int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
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.CacheImpl
 
compact(boolean, boolean) - Method in class org.infinispan.marshall.MarshalledValue
Compacts the references held by this class to a single reference.
compare(T, T) - 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(EntryVersion) - Method in interface org.infinispan.container.versioning.EntryVersion
Compares the given version against the current instance.
compareTo(EntryVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
compareTo(ExperimentalDefaultConsistentHash.Entry) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
Compare this Entry with another Entry.
compareTo(File) - Method in class org.infinispan.io.GridFile
 
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
 
completedLeaveRehash(Address, String, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
completeTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Looks up the SleepyCat transaction associated with the parameter tx.
CompleteTransactionCommand - Class in org.infinispan.commands.remote.recovery
Command used by the recovery tooling for forcing transaction completion .
CompleteTransactionCommand(String) - Constructor for class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
CompleteTransactionCommand(String, Xid, boolean) - Constructor for class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
completionQueue - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
 
complexType(XSComplexType) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
COMPONENT_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
componentFailedToStop(Throwable) - Method in interface org.infinispan.util.logging.Log
 
ComponentMetadata - Class in org.infinispan.factories.components
This class contains all of the metadata and implications expressed via the Scope, SurvivesRestarts, DefaultFactoryFor, ComponentName, Inject, Start and Stop annotations.
ComponentMetadata(Class<?>, List<Method>, List<Method>, List<Method>, boolean, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata
 
ComponentMetadata.InjectMetadata - Class in org.infinispan.factories.components
This class encapsulates metadata on an inject method, such as one annotated with Inject
ComponentMetadata.PrioritizedMethodMetadata - Class in org.infinispan.factories.components
This class encapsulates metadata on a prioritized method, such as one annotated with Start or @Stop
ComponentMetadata.PrioritizedMethodMetadata(String, int) - Constructor for class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
ComponentMetadataPersister - Class in org.infinispan.factories.components
A utility class used by the Infinispan build process to scan metadata and persist it.
ComponentMetadataPersister() - Constructor for class org.infinispan.factories.components.ComponentMetadataPersister
 
ComponentMetadataRepo - Class in org.infinispan.factories.components
This is a repository of component metadata, which is populated when the Infinispan core jar is loaded up.
ComponentMetadataRepo() - Constructor for class org.infinispan.factories.components.ComponentMetadataRepo
 
ComponentName - Annotation Type in org.infinispan.factories.annotations
Mechanism for specifying the name of components to retrieve
componentRegistry - Variable in class org.infinispan.CacheImpl
 
componentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
ComponentRegistry - Class in org.infinispan.factories
Named cache specific components
ComponentRegistry(String, Configuration, AdvancedCache<?, ?>, GlobalComponentRegistry, ClassLoader) - Constructor for class org.infinispan.factories.ComponentRegistry
Creates an instance of the component registry.
ComponentRegistryUtils - Class in org.infinispan.query.impl
 
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.
compute(K, ConcurrentHashMapV8.RemappingFunction<? super K, V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Computes and enters a new mapping value given a key and its current mapped value (or null if there is no current mapping).
computeGroup(T, String) - Method in interface org.infinispan.distribution.group.Grouper
Compute the group for a given key
computeIfAbsent(K, ConcurrentHashMapV8.MappingFunction<? super K, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
If the specified key is not already associated with a value, computes its value using the given mappingFunction and enters it into the map.
computeLeavers(List<Address>) - Method in class org.infinispan.cacheviews.CacheViewInfo
 
computeMissingJoiners(Collection<Address>) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
 
computeNewHashes(Transport, Log, int, int, short, int, int) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
computeNewHashes(Transport, Log, int, int, short, int, int) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec11
 
computeOrphan(Collection<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Check's if this transaction's originator is no longer part of the cluster (orphan transaction) and updates RecoveryAwareRemoteTransaction.isOrphan().
concurrencyLevel - Variable in class org.infinispan.config.Configuration.LockingType
Deprecated.  
concurrencyLevel(Integer) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
concurrencyLevel(Integer) - Method in interface org.infinispan.config.FluentConfiguration.LockingConfig
Deprecated. Concurrency level for lock containers.
concurrencyLevel() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Concurrency level for lock containers.
concurrencyLevel(int) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Concurrency level for lock containers.
ConcurrentHashMapV8<K,V> - Class in org.infinispan.util.concurrent.jdk8backported
A hash table supporting full concurrency of retrievals and high expected concurrency for updates.
ConcurrentHashMapV8() - Constructor for class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new, empty map with the default initial table size (16),
ConcurrentHashMapV8(int) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new, empty map with an initial table size accommodating the specified number of elements without the need to dynamically resize.
ConcurrentHashMapV8(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new map with the same mappings as the given map.
ConcurrentHashMapV8(int, float) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity) and initial table density (loadFactor).
ConcurrentHashMapV8(int, float, int) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity), table density (loadFactor), and number of concurrently updating threads (concurrencyLevel).
ConcurrentHashMapV8.MappingFunction<K,V> - Interface in org.infinispan.util.concurrent.jdk8backported
A function computing a mapping from the given key to a value.
ConcurrentHashMapV8.RemappingFunction<K,V> - Interface in org.infinispan.util.concurrent.jdk8backported
A function computing a new mapping given a key and its current mapped value (or null if there is no current mapping).
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.
ConcurrentMapFactory - Class in org.infinispan.util.concurrent
A factory for ConcurrentMaps.
ConcurrentMapFactory() - Constructor for class org.infinispan.util.concurrent.ConcurrentMapFactory
 
ConcurrentWeakKeyHashMap<K,V> - Class in org.infinispan.util.concurrent
An alternative weak-key ConcurrentMap which is similar to ConcurrentHashMap.
ConcurrentWeakKeyHashMap(int, float, int) - Constructor for class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Creates a new, empty map with the specified initial capacity, load factor and concurrency level.
ConcurrentWeakKeyHashMap(int, float) - Constructor for class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Creates a new, empty map with the specified initial capacity and load factor and with the default reference types (weak keys, strong values), and concurrencyLevel (16).
ConcurrentWeakKeyHashMap(int) - Constructor for class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Creates a new, empty map with the specified initial capacity, and with default reference types (weak keys, strong values), load factor (0.75) and concurrencyLevel (16).
ConcurrentWeakKeyHashMap() - Constructor for class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Creates a new, empty map with a default initial capacity (16), reference types (weak keys, strong values), default load factor (0.75) and concurrencyLevel (16).
ConcurrentWeakKeyHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Creates a new map with the same mappings as the given map.
ConcurrentWeakKeyHashMap.ReusableIterator<E> - Interface in org.infinispan.util.concurrent
 
config - Variable in class org.infinispan.CacheImpl
 
Config - Class in org.infinispan.nearcache.cdi
Configuration of the cache
Config() - Constructor for class org.infinispan.nearcache.cdi.Config
 
config - Variable in class org.infinispan.transaction.AbstractEnlistmentAdapter
 
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
 
ConfigFilesConvertor - Class in org.infinispan.configuration.parsing
Class used for converting different configuration files to INFINISPAN format.
ConfigFilesConvertor() - Constructor for class org.infinispan.configuration.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 - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
Configuration - Class in org.infinispan.config
Deprecated. This class is deprecated. Use Configuration instead.
Configuration() - Constructor for class org.infinispan.config.Configuration
Deprecated.  
Configuration - Class in org.infinispan.configuration.cache
 
configuration - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
configuration - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
configuration - Variable in class org.infinispan.remoting.transport.AbstractTransport
 
configuration - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
configuration - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
configuration - Variable in class org.infinispan.transaction.TransactionTable
 
configuration - Variable in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
Configuration.AsyncType - Class in org.infinispan.config
Deprecated. 
Configuration.BooleanAttributeType - Class in org.infinispan.config
Deprecated. 
Configuration.BooleanAttributeType() - Constructor for class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
Configuration.BooleanAttributeType(String) - Constructor for class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
Configuration.CacheMode - Enum in org.infinispan.config
Deprecated. 
Configuration.ClusteringType - Class in org.infinispan.config
Deprecated. 
Configuration.ClusteringType(Configuration.CacheMode) - Constructor for class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
Configuration.ClusteringType() - Constructor for class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
Configuration.ClusteringTypeAdapter - Class in org.infinispan.config
Deprecated. 
Configuration.ClusteringTypeAdapter() - Constructor for class org.infinispan.config.Configuration.ClusteringTypeAdapter
Deprecated.  
Configuration.CustomInterceptorPositionType - Class in org.infinispan.config
Deprecated. 
Configuration.CustomInterceptorPositionType(CommandInterceptor, Configuration.CustomInterceptorsType) - Constructor for class org.infinispan.config.Configuration.CustomInterceptorPositionType
Deprecated.  
Configuration.CustomInterceptorsType - Class in org.infinispan.config
Deprecated. 
Configuration.CustomInterceptorsType() - Constructor for class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
Configuration.DataContainerType - Class in org.infinispan.config
Deprecated. 
Configuration.DataContainerType() - Constructor for class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
Configuration.DeadlockDetectionType - Class in org.infinispan.config
Deprecated. 
Configuration.DeadlockDetectionType() - Constructor for class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
Configuration.EvictionType - Class in org.infinispan.config
Deprecated. 
Configuration.EvictionType() - Constructor for class org.infinispan.config.Configuration.EvictionType
Deprecated.  
Configuration.ExpirationType - Class in org.infinispan.config
Deprecated. 
Configuration.ExpirationType() - Constructor for class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
Configuration.HashType - Class in org.infinispan.config
Deprecated. 
Configuration.HashType() - Constructor for class org.infinispan.config.Configuration.HashType
Deprecated.  
Configuration.InvocationBatching - Class in org.infinispan.config
Deprecated. 
Configuration.InvocationBatching() - Constructor for class org.infinispan.config.Configuration.InvocationBatching
Deprecated.  
Configuration.JmxStatistics - Class in org.infinispan.config
Deprecated. 
Configuration.JmxStatistics() - Constructor for class org.infinispan.config.Configuration.JmxStatistics
Deprecated.  
Configuration.L1Type - Class in org.infinispan.config
Deprecated. 
Configuration.L1Type() - Constructor for class org.infinispan.config.Configuration.L1Type
Deprecated.  
Configuration.LazyDeserialization - Class in org.infinispan.config
Deprecated. 
Configuration.LazyDeserialization() - Constructor for class org.infinispan.config.Configuration.LazyDeserialization
Deprecated.  
Configuration.LockingType - Class in org.infinispan.config
Deprecated. 
Configuration.LockingType() - Constructor for class org.infinispan.config.Configuration.LockingType
Deprecated.  
Configuration.QueryConfigurationBean - Class in org.infinispan.config
Deprecated. 
Configuration.QueryConfigurationBean() - Constructor for class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
Configuration.RecoveryType - Class in org.infinispan.config
Deprecated. 
Configuration.RecoveryType() - Constructor for class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
Configuration.StateRetrievalType - Class in org.infinispan.config
Deprecated. 
Configuration.StateRetrievalType() - Constructor for class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
Configuration.StoreAsBinary - Class in org.infinispan.config
Deprecated. 
Configuration.StoreAsBinary() - Constructor for class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
Configuration.SyncType - Class in org.infinispan.config
Deprecated. 
Configuration.SyncType() - Constructor for class org.infinispan.config.Configuration.SyncType
Deprecated.  
Configuration.TransactionType - Class in org.infinispan.config
Deprecated. 
Configuration.TransactionType(String) - Constructor for class org.infinispan.config.Configuration.TransactionType
Deprecated.  
Configuration.TransactionType() - Constructor for class org.infinispan.config.Configuration.TransactionType
Deprecated.  
Configuration.UnsafeType - Class in org.infinispan.config
Deprecated. 
Configuration.UnsafeType() - Constructor for class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
Configuration.VersioningConfigurationBean - Class in org.infinispan.config
Deprecated. 
Configuration.VersioningConfigurationBean() - Constructor for class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
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.
ConfigurationBuilder - Class in org.infinispan.configuration.cache
 
ConfigurationBuilder() - Constructor for class org.infinispan.configuration.cache.ConfigurationBuilder
 
ConfigurationBuilderHolder - Class in org.infinispan.configuration.parsing
 
ConfigurationBuilderHolder() - Constructor for class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
ConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ConfigurationDoc - Annotation Type in org.infinispan.config
Configuration bean element annotated with @ConfigurationDoc indicates that the element should be included in configuration reference.
ConfigurationDocRef - Annotation Type in org.infinispan.config
Configuration bean element annotated with @ConfigurationDocRef indicates that the element should be included in configuration reference but that the description should be extracted from bean class target and its targetElement (method or field).
ConfigurationDocs - Annotation Type in org.infinispan.config
Configuration bean element annotated with @ConfigurationDocs wraps multiple @ConfigurationDoc annotations
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
 
configurationOverrides - Variable in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
ConfigurationOverrides - Class in org.infinispan.spring
Helper class to override select values in an Infinispan Configuration.
ConfigurationOverrides() - Constructor for class org.infinispan.spring.ConfigurationOverrides
 
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
 
configurationProperties() - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
ConfigurationPropertiesOverrides - Class in org.infinispan.spring
Provides a mechanism to override selected configuration properties using explicit setters for each configuration setting.
ConfigurationPropertiesOverrides() - Constructor for class org.infinispan.spring.ConfigurationPropertiesOverrides
 
ConfigurationRegistry - Interface in org.infinispan.config
A registry for Configurations.
ConfigurationValidatingVisitor - Class in org.infinispan.config
Deprecated. Belongs to old configuration and so will dissapear in future releases
ConfigurationValidatingVisitor() - Constructor for class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
ConfigureCache - Annotation Type in org.infinispan.cdi
This annotation is used to define a cache Configuration.
configuredAsync - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
configuredSync - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
CONNECT_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
connectionInJndiNotFound(String) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
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() - Method in class org.infinispan.configuration.cache.HashConfiguration
The consistent hash in use.
consistentHash(ConsistentHash) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
The consistent hash in use.
ConsistentHash - Interface in org.infinispan.distribution.ch
A consistent hash algorithm implementation.
consistentHashClass - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
consistentHashClass(Class<? extends ConsistentHash>) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
consistentHashClass(Class<? extends ConsistentHash>) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated. Fully qualified name of class providing consistent hash algorithm
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.ch
A helper class that handles the construction of consistent hash instances based on configuration.
ConsistentHashHelper() - Constructor for class org.infinispan.distribution.ch.ConsistentHashHelper
 
ConsistentHashV1 - Class in org.infinispan.client.hotrod.impl.consistenthash
Version one consistent hash function based on MurmurHash2;
ConsistentHashV1(Random) - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
ConsistentHashV1() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
ConsistentHashV2 - Class in org.infinispan.client.hotrod.impl.consistenthash
Version 2 of the ConsistentHash function.
ConsistentHashV2() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV2
 
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.CacheMembershipManagerFactory
 
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.EntryMetaFactory
 
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>, String) - 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<RecoveryManager>) - Method in class org.infinispan.factories.RecoveryManagerFactory
 
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.TransactionSynchronizationRegistryFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.TransactionTableFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.TransportFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.VersioningMetaFactory
 
constructDouble(Class<?>, Object) - Static method in class org.infinispan.rhq.RhqUtil
 
constructDouble(Class<?>, Object) - Static method in class org.infinispan.util.Util
 
constructNumericMeasure(Class<?>, Object, MeasurementScheduleRequest) - Static method in class org.infinispan.rhq.RhqUtil
 
ContainerCacheManagerFactoryBean - Class in org.infinispan.spring.provider
FactoryBean for creating a CacheManager for a pre-defined CacheContainer.
ContainerCacheManagerFactoryBean(CacheContainer) - Constructor for class org.infinispan.spring.provider.ContainerCacheManagerFactoryBean
 
containRemoteTx(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
contains(Address) - Method in class org.infinispan.cacheviews.CacheView
 
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.concurrent.ConcurrentWeakKeyHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Legacy method testing if some key maps into the specified value in this table.
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.ForwardingList
 
contains(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
contains(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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.ForwardingList
 
containsAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
containsAny(Collection<Address>) - Method in class org.infinispan.cacheviews.CacheView
 
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.atomic.FineGrainedAtomicHashMapProxy
 
containsKey(Object) - Method in class org.infinispan.CacheImpl
 
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.DecoratedCache
 
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.concurrent.BoundedConcurrentHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
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(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.ContainsKeyOperation
 
containsLocalModeFlag - Variable in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
containsLocalTx(Transaction) - Method in class org.infinispan.transaction.TransactionTable
Returns true if the given transaction is already registered with the transaction table.
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.atomic.FineGrainedAtomicHashMapProxy
 
containsValue(Object) - Method in class org.infinispan.CacheImpl
 
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.concurrent.BoundedConcurrentHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
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.
context - Variable in class org.infinispan.rhq.CacheManagerComponent
 
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
 
Contracts - Class in org.infinispan.cdi.util
An helper class providing useful assertion methods.
coordinator - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
copy() - Method in class org.infinispan.atomic.AtomicHashMap
 
copy() - Method in class org.infinispan.commands.tx.PrepareCommand
 
copy() - Method in class org.infinispan.io.ByteBuffer
 
copy(InputStream, OutputStream, byte[]) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream.
copy(InputStream, OutputStream, int) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream.
copy(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream.
copyb(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream wrapping streams in buffers as needed.
copyForUpdate(DataContainer, boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
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
 
copySome(InputStream, OutputStream, byte[], long) - Static method in class org.infinispan.util.stream.Streams
Copy a limited number of bytes from the input stream to the output stream.
copySome(InputStream, OutputStream, int, long) - Static method in class org.infinispan.util.stream.Streams
Copy a limited number of bytes from the input stream to the output stream.
copySome(InputStream, OutputStream, long) - Static method in class org.infinispan.util.stream.Streams
Copy a limited number of bytes from the input stream to the output stream.
copyStateFlagsFrom(StateChangingEntry) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
copyStateFlagsFrom(StateChangingEntry) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
copyStateFlagsFrom(StateChangingEntry) - Method in interface org.infinispan.container.entries.StateChangingEntry
 
copyWithouthRemotableFlags(Set<Flag>) - Static method in enum org.infinispan.context.Flag
Creates a copy of a Flag Set removing instances of FAIL_SILENTLY.
couldNoInvalidateConnection(TcpTransport, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotAcquireLockForEviction(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotAcquireSharedLock() - Method in interface org.infinispan.util.logging.Log
 
couldNotCompleteInjectedTransaction(Throwable) - Method in interface org.infinispan.util.logging.Log
 
couldNotDestroyC3p0ConnectionPool(String, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
couldNotFetchTransport(Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotFindAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
couldNotFindDescriptionField() - Method in interface org.infinispan.util.logging.Log
 
couldNotFindPeerForState() - Method in interface org.infinispan.util.logging.Log
 
couldNotFindPropertiesFile(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotInitializeModule(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInstantiaterTransformerClass(Class<?>, Exception) - Method in interface org.infinispan.query.logging.Log
 
couldNotInstantiateTransactionManager(Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInvokeSetOnAttribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in interface org.infinispan.util.logging.Log
 
couldNotReleaseConnection(TcpTransport, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotResolveConfigurationSchema(String, String, String) - Method in interface org.infinispan.util.logging.Log
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
counter - Static variable in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
CQCreateEagerQuery - Class in org.infinispan.query.clustered.commandworkers
CQCreateEagerQuery.
CQCreateEagerQuery() - Constructor for class org.infinispan.query.clustered.commandworkers.CQCreateEagerQuery
 
CQCreateLazyQuery - Class in org.infinispan.query.clustered.commandworkers
CQCreateLazyQuery.
CQCreateLazyQuery() - Constructor for class org.infinispan.query.clustered.commandworkers.CQCreateLazyQuery
 
CQGetResultSize - Class in org.infinispan.query.clustered.commandworkers
CQGetResultSize.
CQGetResultSize() - Constructor for class org.infinispan.query.clustered.commandworkers.CQGetResultSize
 
CQKillLazyIterator - Class in org.infinispan.query.clustered.commandworkers
CQKillLazyIterator.
CQKillLazyIterator() - Constructor for class org.infinispan.query.clustered.commandworkers.CQKillLazyIterator
 
CQLazyFetcher - Class in org.infinispan.query.clustered.commandworkers
CQLazyFetcher.
CQLazyFetcher() - Constructor for class org.infinispan.query.clustered.commandworkers.CQLazyFetcher
 
cr - Variable in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
create(CacheEntry) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance based on the key, value, version and timestamp/lifespan information reflected in the CacheEntry instance passed in.
create(Object, Object, InternalCacheEntry) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance based on the version and timestamp/lifespan information reflected in the CacheEntry instance passed in.
create(Object, Object, EntryVersion) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(Object, Object, EntryVersion, long, long) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(Object, Object, EntryVersion, long, long, long, long) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(Object, Object, EntryVersion) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(CacheEntry) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(Object, Object, InternalCacheEntry) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(Object, Object, EntryVersion, long, long, long, long) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(Object, Object, EntryVersion, long, long) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(Object, Object, EntryVersion) - Method in class org.infinispan.container.VersionedInternalEntryFactoryImpl
 
create(Object, Object, EntryVersion, long, long, long, long) - Method in class org.infinispan.container.VersionedInternalEntryFactoryImpl
 
create(Object, Object, EntryVersion, long, long) - Method in class org.infinispan.container.VersionedInternalEntryFactoryImpl
 
create(Object) - Static method in class org.infinispan.remoting.responses.SuccessfulResponse
 
create(T) - Static method in class org.infinispan.util.ByRef
 
createAndWire(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
 
createBackingEmbeddedCacheManager() - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
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.
createCacheManager(AbstractEmbeddedCacheManagerFactory.ConfigurationContainer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
createComparator() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
Returns a new comparator instance based on JdbmCacheStoreConfig.setComparatorClassName(String).
createConsistentHash(Configuration, Collection<Address>) - Static method in class org.infinispan.distribution.ch.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, Collection<Address>, Address...) - Static method in class org.infinispan.distribution.ch.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, Collection<Address>, Collection<Address>) - Static method in class org.infinispan.distribution.ch.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(ConsistentHash, Collection<Address>) - Static method in class org.infinispan.distribution.ch.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(ConsistentHash, Collection<Address>, Address...) - Static method in class org.infinispan.distribution.ch.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(List<Address>) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
createConsistentHash(List<Address>) - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
createConsistentHash(List<Address>) - Method in class org.infinispan.statetransfer.DummyInvalidationStateTransferManagerImpl
Deprecated.  
createConsistentHash(List<Address>) - Method in class org.infinispan.statetransfer.ReplicatedStateTransferManagerImpl
 
createCurrentTransaction(Environment) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
 
created - Variable in class org.infinispan.container.entries.MortalCacheValue
 
createDatabase(Environment, String) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
Open the database, creating it if it doesn't exist.
createEagerIterator(HSQuery, Cache<?, ?>) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
createEnvironment(File, Properties) - Method in class org.infinispan.loaders.bdbje.BdbjeResourceFactory
Open the environment, creating it if it doesn't exist.
createEvent(Cache<K, V>, Event.Type) - Static method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
createExternal(Class<?>, ObjectInput, Creator) - Method in class org.infinispan.marshall.jboss.JBossExternalizerAdapter
 
createFolder(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
Factory method for GlobalTransactions
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
createInvocationContext(boolean, int) - Method in interface org.infinispan.context.InvocationContextContainer
If we are in a tx scope this will return an TxInvocationContext.
createInvocationContext(Transaction) - Method in interface org.infinispan.context.InvocationContextContainer
Creates an invocation context
createInvocationContext(boolean, int) - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createInvocationContext(Transaction) - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createInvocationContext(boolean, int) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createInvocationContext(Transaction) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createLazyIterator(HSQuery, Cache<?, ?>, UUID) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
createMarshalledValue(Object, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
createMarshaller() - Method in class org.infinispan.factories.MarshallerFactory
 
createMarshaller(MarshallingConfiguration) - Method in class org.infinispan.marshall.jboss.JBossMarshallerFactory
 
createNewEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
 
createNewFile() - Method in class org.infinispan.io.GridFile
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
createNodeInCache(AdvancedCache<?, ?>, Fqn) - Method in class org.infinispan.tree.TreeStructureSupport
 
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.NonTransactionalInvocationContextContainer
 
createNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createOutput(String) - Method in class org.infinispan.lucene.InfinispanDirectory
createPendingView(CacheView) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
Called on the coordinator to create the view that will be prepared next.
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(Address) - Method in interface org.infinispan.context.InvocationContextContainer
Returns an NonTxInvocationContext whose NonTxInvocationContext.isOriginLocal() flag will be true.
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in class org.infinispan.context.AbstractInvocationContextContainer
 
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in interface org.infinispan.context.InvocationContextContainer
As InvocationContextContainer.createRemoteInvocationContext(org.infinispan.remoting.transport.Address), but returning the flags to the context from the Command if any Flag was set.
createRemoteTransaction(GlobalTransaction, WriteCommand[]) - Method in class org.infinispan.transaction.TransactionTable
Creates and register a RemoteTransaction with no modifications.
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in interface org.infinispan.context.InvocationContextContainer
Returns an RemoteTxInvocationContext.
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createResource(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
createSingleKeyNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
Will create an NonTxInvocationContext with the NonTxInvocationContext.isOriginLocal() returning true.
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createStateTransferTask(int, List<Address>, boolean) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
createStateTransferTask(int, List<Address>, boolean) - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
createStateTransferTask(int, List<Address>, boolean) - Method in class org.infinispan.statetransfer.DummyInvalidationStateTransferManagerImpl
Deprecated.  
createStateTransferTask(int, List<Address>, boolean) - Method in class org.infinispan.statetransfer.ReplicatedStateTransferManagerImpl
 
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
 
createTemplateConfiguration() - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
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.NonTransactionalInvocationContextContainer
 
createTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createUnmarshaller(MarshallingConfiguration) - Method in class org.infinispan.marshall.jboss.JBossMarshallerFactory
 
createValue(CacheEntry) - Method in interface org.infinispan.container.InternalEntryFactory
Creates an InternalCacheValue based on the InternalCacheEntry passed in.
createValue(CacheEntry) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
createValue(CacheEntry) - Method in class org.infinispan.container.VersionedInternalEntryFactoryImpl
 
createWrappedEntry(Object, Object, EntryVersion, boolean, boolean, long) - Method in class org.infinispan.container.EntryFactoryImpl
 
createWrappedEntry(Object, Object, EntryVersion, boolean, boolean, long) - Method in class org.infinispan.container.IncrementalVersionableEntryFactoryImpl
 
ctxHolder - Variable in class org.infinispan.context.AbstractInvocationContextContainer
 
CURRENT - Static variable in enum org.infinispan.configuration.parsing.Namespace
The current namespace version.
current() - Static method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.
CURRENT_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of entries currently in the Hot Rod server
currentMillisFromNanotime() - Static method in class org.infinispan.util.Util
System.nanoTime() is less expensive than System.currentTimeMillis() and better suited to measure time intervals.
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) - Constructor for class org.infinispan.config.CustomInterceptorConfig
Constructs an interceptor config based on the supplied interceptor instance.
customInterceptorExpectsInjection(String) - Method in interface org.infinispan.util.logging.Log
 
customInterceptors() - Method in class org.infinispan.configuration.cache.Configuration
 
customInterceptors() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
customInterceptors() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
CustomInterceptorsConfiguration - Class in org.infinispan.configuration.cache
Configures custom interceptors to be added to the cache.
CustomInterceptorsConfiguration() - Constructor for class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
CustomInterceptorsConfigurationBuilder - Class in org.infinispan.configuration.cache
Configures custom interceptors to be added to the cache.

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 - Variable in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
dataContainer(DataContainer) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
dataContainer(DataContainer) - Method in interface org.infinispan.config.FluentConfiguration.DataContainerConfig
Deprecated.  
dataContainer() - Method in class org.infinispan.configuration.cache.Configuration
 
dataContainer() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
dataContainer() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
dataContainer() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
Data container implementation in use
dataContainer(DataContainer) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Specify the data container in use
DataContainer - Interface in org.infinispan.container
The main internal data structure which stores entries
dataContainer - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
dataContainer - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
dataContainer - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
dataContainerClass - Variable in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
dataContainerClass(Class<? extends DataContainer>) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
dataContainerClass(Class<? extends DataContainer>) - Method in interface org.infinispan.config.FluentConfiguration.DataContainerConfig
Deprecated.  
DataContainerConfiguration - Class in org.infinispan.configuration.cache
Controls the data container for the cache.
DataContainerConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls the data container for the cache.
DataContainerFactory - Class in org.infinispan.factories
Constructs the data container
DataContainerFactory() - Constructor for class org.infinispan.factories.DataContainerFactory
 
DataLocality - Enum in org.infinispan.distribution
Used to determine whether a key is mapped to a local node.
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
 
DataRehashed - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a rehash starts or ends.
DataRehashedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
An event passed in to methods annotated with DataRehashed.
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
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
 
DeadlockDetectingInterceptor - Class in org.infinispan.interceptors
This interceptor populates the DldGlobalTransaction 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
 
deadlockDetection() - Method in class org.infinispan.configuration.cache.Configuration
 
deadlockDetection() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
deadlockDetection() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
DeadlockDetectionConfiguration - Class in org.infinispan.configuration.cache
Configures deadlock detection.
DeadlockDetectionConfigurationBuilder - Class in org.infinispan.configuration.cache
Configures deadlock detection.
DEBUG_DEPENDENCIES - Static variable in class org.infinispan.factories.AbstractComponentRegistry
Set the system property infinispan.debugDependencies to true to enable some extra information to errors generated by the component factory.
DECODE - Static variable in class org.infinispan.util.Base64
Specify decoding.
decode(byte[], int, int) - Static method in class org.infinispan.util.Base64
Very low-level access to decoding ASCII characters in the form of a byte array.
decode(String) - Static method in class org.infinispan.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decodeFromFile(String) - Static method in class org.infinispan.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
DecoderState - Enum in org.infinispan.server.core
Protocol decoding state
decodeToFile(String, String) - Static method in class org.infinispan.util.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.infinispan.util.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
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.
DecoratedCache<K,V> - Class in org.infinispan
A decorator to a cache, which can be built with a specific ClassLoader and a set of Flags.
DecoratedCache(AdvancedCache<K, V>, ClassLoader) - Constructor for class org.infinispan.DecoratedCache
 
DecoratedCache(AdvancedCache<K, V>, Flag...) - Constructor for class org.infinispan.DecoratedCache
 
DecoratedCache(AdvancedCache<K, V>, ClassLoader, Flag...) - Constructor for class org.infinispan.DecoratedCache
 
decrement() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Equivalent to add(-1).
DEF_CLASS_COUNT - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
DEF_INSTANCE_COUNT - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
DEFAULT - Static variable in class org.infinispan.distribution.RemoteTransactionLogDetails
 
DEFAULT_BATCH_SIZE - Static variable in class org.infinispan.loaders.jdbc.TableManipulation
 
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.lucene.InfinispanDirectory
Used as default chunk size, can be overriden at construction time.
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.util.stream.Streams
The default buffer size that will be used for buffered operations.
DEFAULT_CACHE_NAME - Static variable in interface org.infinispan.api.BasicCacheContainer
 
DEFAULT_CACHE_NAME_BYTES - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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.ExpandableMarshalledValueByteStream
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
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
Deprecated. Default replication version, from Version.getVersionShort().
DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.configuration.global.GlobalConfiguration
Default replication version, from Version.getVersionShort().
DEFAULT_RECOVERY_INFO_CACHE - Static variable in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
DEFAULT_RECOVERY_INFO_CACHE - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
DEFAULT_TRANSPORT - Static variable in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
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
 
DefaultCacheKey - Class in org.infinispan.cdi.interceptor
Default CacheKey implementation.
DefaultCacheKey(Object[]) - Constructor for class org.infinispan.cdi.interceptor.DefaultCacheKey
 
DefaultCacheKeyGenerator - Class in org.infinispan.cdi.interceptor
Default CacheKeyGenerator implementation.
DefaultCacheKeyGenerator() - Constructor for class org.infinispan.cdi.interceptor.DefaultCacheKeyGenerator
 
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
Deprecated. Use DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.cache.Configuration) instead
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
Deprecated. Use DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.cache.Configuration, boolean) instead
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
Deprecated. Use DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.global.GlobalConfiguration) instead
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
Deprecated. Use DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.global.GlobalConfiguration, boolean) instead
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
Deprecated. 
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
Deprecated. Use DefaultCacheManager.DefaultCacheManager(org.infinispan.configuration.global.GlobalConfiguration, org.infinispan.configuration.cache.Configuration, boolean) instead
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(ConfigurationBuilderHolder, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the holder passed in to read configuration settings.
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.
DefaultCacheResolver - Class in org.infinispan.cdi.interceptor
Default CacheResolver implementation.
DefaultCacheResolver(Instance<EmbeddedCacheManager>) - Constructor for class org.infinispan.cdi.interceptor.DefaultCacheResolver
 
DefaultCacheResolver() - Constructor for class org.infinispan.cdi.interceptor.DefaultCacheResolver
 
defaultChunkSize - Variable in class org.infinispan.io.GridFilesystem
 
defaultClassLoader - Variable in class org.infinispan.factories.AbstractComponentRegistry
 
defaultClusteredBuilder() - Static method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultConfiguration - Variable in class org.infinispan.manager.DefaultCacheManager
 
defaultConfiguration - Variable in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory.ConfigurationContainer
 
DefaultConsistentHash - Class in org.infinispan.distribution.ch
 
DefaultConsistentHash() - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHash
 
DefaultConsistentHash(Hash) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHash
 
DefaultConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
DefaultConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHash.Externalizer
 
DefaultContextClassResolver - Class in org.infinispan.marshall.jboss
This class refines ContextClassLoader to add a default class loader in case the context class loader is null.
DefaultContextClassResolver(ClassLoader) - Constructor for class org.infinispan.marshall.jboss.DefaultContextClassResolver
 
DefaultDataContainer - Class in org.infinispan.container
DefaultDataContainer is both eviction and non-eviction based data container.
DefaultDataContainer(int) - Constructor for class org.infinispan.container.DefaultDataContainer
 
DefaultDataContainer(int, int, EvictionStrategy, EvictionThreadPolicy) - Constructor for class org.infinispan.container.DefaultDataContainer
 
DefaultDataContainer.EntryIterator - Class in org.infinispan.container
 
DefaultEmbeddedCacheConfigurationProducer - Class in org.infinispan.cdi
The default embedded cache Configuration producer.
DefaultEmbeddedCacheConfigurationProducer() - Constructor for class org.infinispan.cdi.DefaultEmbeddedCacheConfigurationProducer
 
DefaultEmbeddedCacheManagerProducer - Class in org.infinispan.cdi
The default EmbeddedCacheManager producer.
DefaultEmbeddedCacheManagerProducer() - Constructor for class org.infinispan.cdi.DefaultEmbeddedCacheManagerProducer
 
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
 
DefaultExecutorService - Class in org.infinispan.distexec
Infinispan's implementation of an ExecutorService and DistributedExecutorService.
DefaultExecutorService(Cache) - Constructor for class org.infinispan.distexec.DefaultExecutorService
Creates a new DefaultExecutorService given a master cache node for local task execution.
DefaultExecutorService(Cache<?, ?>, ExecutorService) - Constructor for class org.infinispan.distexec.DefaultExecutorService
Creates a new DefaultExecutorService given a master cache node and an ExecutorService for parallel execution of task ran on this node.
DefaultExecutorService.DistributedRunnableFuture<V> - Class in org.infinispan.distexec
DistributedRunnableFuture is essentially a Future wrap around DistributedExecuteCommand.
DefaultExecutorService.DistributedRunnableFuture(DistributedExecuteCommand<V>) - Constructor for class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
Creates a DistributedRunnableFuture that will upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
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.
defaultLifespan - Variable in class org.infinispan.CacheSupport
 
defaultMaxIdleTime - Variable in class org.infinispan.CacheSupport
 
DefaultRemoteCacheManagerProducer - Class in org.infinispan.cdi
The default RemoteCacheManager producer.
DefaultRemoteCacheManagerProducer() - Constructor for class org.infinispan.cdi.DefaultRemoteCacheManagerProducer
 
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
 
defaultTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
DefaultTwoWayKey2StringMapper - Class in org.infinispan.loaders.keymappers
Default implementation for TwoWayKey2StringMapper that knows how to handle all primitive wrapper keys and Strings.
DefaultTwoWayKey2StringMapper() - Constructor for class org.infinispan.loaders.keymappers.DefaultTwoWayKey2StringMapper
 
defaultVisit(AbstractConfigurationBean) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
DeferredReturnFuture<V> - Class in org.infinispan.util.concurrent
This is a notifying and notifiable future whose return value is not known at construction time.
DeferredReturnFuture() - Constructor for class org.infinispan.util.concurrent.DeferredReturnFuture
 
defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
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
Deprecated. Use #defineConfiguration(String, String, org.infinispan.configuration.cache.Configuration) instead
defineConfiguration(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Defines a named cache's configuration using the following algorithm:

Unlike previous versions of Infinispan, this method does not build on an existing configuration (default or named).

defineConfiguration(String, String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated. Use EmbeddedCacheManager.defineConfiguration(String, org.infinispan.configuration.cache.Configuration) instead
delegate() - Method in class org.infinispan.util.EnumerationList
 
delegate() - Method in class org.infinispan.util.ForwardingList
 
delegatePurgeExpired() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
DelegatingConfigurationVisitor - Class in org.infinispan.config
DelegatingConfigurationVisitor wraps a list of ConfigurationBeanVisitor visitors and delegates visitor callbacks to all delegates in the list.
DelegatingConfigurationVisitor(ConfigurationBeanVisitor[]) - Constructor for class org.infinispan.config.DelegatingConfigurationVisitor
 
DelegatingConfigurationVisitor(List<ConfigurationBeanVisitor>) - Constructor for class org.infinispan.config.DelegatingConfigurationVisitor
 
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.
DeltaAwareCacheEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates DeltaAware and Delta semantics when writes are initiated, committed or rolled back.
DeltaAwareCacheEntry(Object, DeltaAware, CacheEntry) - Constructor for class org.infinispan.container.entries.DeltaAwareCacheEntry
 
DeltaAwareCacheEntry.Flags - Enum in org.infinispan.container.entries
 
deltaMapKey - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
deltas - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
Demo - Class in org.infinispan.demo
 
Demo(String[]) - Constructor for class org.infinispan.demo.Demo
 
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, Cache<?, ?>) - 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, Cache<?, ?>) - 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() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
Shuts down the SpringEmbeddedCacheManager instance created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
stop the RemoteCacheManager created by this factory.
destroy() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
Shuts down the EmbeddedCacheManager instance created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
Shuts down the org.infinispan.Cache created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
Shuts down the org.infinispan.Cache created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
stop the RemoteCacheManager created by this factory.
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
destroyLazyQuery(Cache<?, ?>, UUID) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
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.ch.ExperimentalDefaultConsistentHash.Entry
 
DIR - Static variable in class org.infinispan.io.GridFile.Metadata
 
disable() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.InvocationBatching
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.JmxStatistics
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.LazyDeserialization
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
disable() - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentConfiguration.DeadlockDetectionConfig
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentConfiguration.IndexingConfig
Deprecated. Indexing is disabled by default, but using the fluent API entering the FluentTypes.indexing() method enables Indexing implicitly.
disable() - Method in interface org.infinispan.config.FluentConfiguration.InvocationBatchingConfig
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentConfiguration.L1Config
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentConfiguration.RecoveryConfig
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentConfiguration.StoreAsBinaryConfig
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentConfiguration.VersioningConfig
Deprecated.  
disable() - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated.  
disable() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
disable() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Disable deadlock detection
disable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Disable indexing
disable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Disable statistics gathering and reporting
disable() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Disable recovery for this cache
disable() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Enable the singleton store cache store
disable() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Disables storing both keys and values as binary.
disable() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
disabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Disable grouping support so that Group annotations are not used and any configured groupers will not be be invoked
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.
disableOnRehash() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Entries removed due to a rehash will be removed altogether rather than bring moved to L1.
disableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Disable the background reaper to test entries for expiration.
disconnectAndCloseJGroups() - Method in interface org.infinispan.util.logging.Log
 
discoverResource(Configuration, ResourceDiscoveryContext<JMXComponent<?>>) - Method in class org.infinispan.rhq.CacheManagerDiscovery
 
discoverResources(ResourceDiscoveryContext<CacheManagerComponent>) - Method in class org.infinispan.rhq.CacheDiscovery
Run the discovery
discoverResources(ResourceDiscoveryContext<JMXComponent<?>>) - Method in class org.infinispan.rhq.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
 
DistributedCallable<K,V,T> - Interface in org.infinispan.distexec
A task that returns a result and may throw an exception capable of being executed in another JVM.
DistributedExecuteCommand<V> - Class in org.infinispan.commands.read
DistributedExecuteCommand is used to migrate Callable and execute it in remote JVM.
DistributedExecuteCommand(Collection<Object>, Callable<V>) - Constructor for class org.infinispan.commands.read.DistributedExecuteCommand
 
DistributedExecuteCommand() - Constructor for class org.infinispan.commands.read.DistributedExecuteCommand
 
DistributedExecutionCompletionService<V> - Class in org.infinispan.distexec
A CompletionService that uses a supplied DistributedExecutorService to execute tasks.
DistributedExecutionCompletionService(DistributedExecutorService) - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService
Creates an ExecutorCompletionService using the supplied executor for base task execution and a LinkedBlockingQueue as a completion queue.
DistributedExecutionCompletionService(DistributedExecutorService, BlockingQueue<NotifyingFuture<V>>) - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService
Creates an ExecutorCompletionService using the supplied executor for base task execution and the supplied queue as its completion queue.
DistributedExecutionCompletionService(DistributedExecutorService, BlockingQueue<NotifyingFuture<V>>, DistributedExecutionCompletionService<V>.QueueingListener) - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService
This constructor is here if someone wants to override this class and provide their own QueueingListener to possibly listen in on futures being finished
DistributedExecutionCompletionService.QueueingListener - Class in org.infinispan.distexec
 
DistributedExecutionCompletionService.QueueingListener() - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService.QueueingListener
 
DistributedExecutorService - Interface in org.infinispan.distexec
An ExecutorService that provides methods to submit tasks for execution on a cluster of Infinispan nodes.
DistributedIterator - Class in org.infinispan.query.clustered
DistributedIterator.
DistributedIterator(Sort, int, int, HashMap<UUID, ClusteredTopDocs>, AdvancedCache<?, ?>) - Constructor for class org.infinispan.query.clustered.DistributedIterator
 
DistributedLazyIterator - Class in org.infinispan.query.clustered
DistributedLazyIterator.
DistributedLazyIterator(Sort, int, int, UUID, HashMap<UUID, ClusteredTopDocs>, ExecutorService, AdvancedCache<?, ?>) - Constructor for class org.infinispan.query.clustered.DistributedLazyIterator
 
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<Object, Integer>, Cache<?, ?>, Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
 
DistributedSegmentReadLocker(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
 
DistributedStateTransferManagerImpl - Class in org.infinispan.statetransfer
The distributed mode implementation of StateTransferManager
DistributedStateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
Default constructor
DistributedStateTransferTask - Class in org.infinispan.statetransfer
Task which handles view changes (joins, merges or leaves) and rebalances keys using a push based approach.
DistributedStateTransferTask(RpcManager, Configuration, DataContainer, DistributedStateTransferManagerImpl, DistributionManager, StateTransferLock, CacheNotifier, int, Collection<Address>, ConsistentHash, ConsistentHash, boolean, TransactionTable) - Constructor for class org.infinispan.statetransfer.DistributedStateTransferTask
 
distributedSyncTimeout(Long) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated.  
distributedSyncTimeout - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
distributedSyncTimeout(Long) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
distributedSyncTimeout() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
distributedSyncTimeout(long) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Timeout for coordinating cluster formation when nodes join or leave the cluster.
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
Default constructor
distributionManagerNotJoined() - Method in interface org.infinispan.util.logging.Log
 
distributionManagerNotStarted() - Method in interface org.infinispan.util.logging.Log
 
DistributionResponseGenerator - Class in org.infinispan.remoting.responses
A response generator for the DIST cache mode
DistributionResponseGenerator() - Constructor for class org.infinispan.remoting.responses.DistributionResponseGenerator
 
DldGlobalTransaction - Class in org.infinispan.transaction.xa
This class is used when deadlock detection is enabled.
DldGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction
 
DldGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction
 
DldGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
 
DldGlobalTransaction.Externalizer() - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
dm - Variable in class org.infinispan.commands.read.MapReduceCommand
 
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
 
docIndex - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
doConnectionFactoryInitialization(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
Keeps a reference to the connection factory for further use.
doConnectionFactoryInitialization(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
Keeps a reference to the connection factory for further use.
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.infinispan.ec2demo.web.CacheSearchServlet
 
domain() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
DONT_BREAK_LINES - Static variable in class org.infinispan.util.Base64
Don't break lines when encoding (violates strict Base64 specification)
doPerformStateTransfer() - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
doPerformStateTransfer() - Method in class org.infinispan.statetransfer.DistributedStateTransferTask
 
doPerformStateTransfer() - Method in class org.infinispan.statetransfer.ReplicatedStateTransferTask
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.infinispan.ec2demo.web.CacheSearchServlet
 
doubleValue() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
downgradeLock(L) - Method in class org.infinispan.loaders.LockSupportCacheStore
Downgrade a write lock to a read lock
downgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
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

drainReplQueue() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
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.
DUMMY_CACHE_NAME_FOR_GLOBAL_COMMANDS - Static variable in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
DummyBaseTransactionManager - Class in org.infinispan.transaction.tm
 
DummyBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
DummyInvalidationStateTransferManagerImpl - Class in org.infinispan.statetransfer
Deprecated. This is just a temporary hack, do not rely on it to exist in future versions
DummyInvalidationStateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.DummyInvalidationStateTransferManagerImpl
Deprecated.  
DummyNoXaXid - Class in org.infinispan.transaction.tm
Xid to be used when no XAResource enlistment takes place.
DummyNoXaXid() - Constructor for class org.infinispan.transaction.tm.DummyNoXaXid
 
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(UUID) - Constructor for class org.infinispan.transaction.tm.DummyXid
 
dumpStream() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
dumpStream() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
duplicateAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting that an attribute of a given name has already been declared in this scope.
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
 
duplicateNamedElement(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting that an element of a given type and name has already been declared in this scope.
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>, AdvancedCache<?, ?>, int) - Constructor for class org.infinispan.query.impl.EagerIterator
 
eagerLockingSingleNode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated. starting with Infinispan 5.1 single node locking is used by default
eagerLockingSingleNode(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Deprecated. starting with Infinispan 5.1 single node locking is used by default
eagerLockSingleNode - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
eagerLockSingleNode(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
eagerLockSingleNode(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. starting with Infinispan 5.1 single node locking is used by default
EARLIEST_EXPIRY_TIME - Static variable in class org.infinispan.loaders.cloud.CloudCacheStore
 
Element - Enum in org.infinispan.configuration.parsing
An enumeration of all the recognized XML element local names, by name.
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.
elements() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns an enumeration of the values in this table.
elements() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns an enumeration of the values in this table.
embeddedCacheManager - Variable in class org.infinispan.interceptors.base.BaseCustomInterceptor
 
EmbeddedCacheManager - Interface in org.infinispan.manager
EmbeddedCacheManager is an CacheManager that runs in the same JVM as the client.
EmbeddedCacheManagerStartupException - Exception in org.infinispan.manager
An exception to encapsulate an error when starting up a cache manager
EmbeddedCacheManagerStartupException() - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(Throwable) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(String) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(String, Throwable) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
emit(K, V) - Method in interface org.infinispan.distexec.mapreduce.Collector
Intermediate key/value callback used by Mapper implementor
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryActivatedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryCreatedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryEvictedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryInvalidatedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryLoadedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryModifiedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryPassivatedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryRemovedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.CacheEntryVisitedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.TransactionCompletedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cache.TransactionRegisteredAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cachemanager.CacheStartedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cachemanager.CacheStoppedAdapter
 
EMPTY - Static variable in class org.infinispan.cdi.event.cachemanager.ViewChangedAdapter
 
empty(XSContentType) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
EMPTY_BYTE_ARRAY - Static variable in class org.infinispan.util.Util
 
EMPTY_CACHE_VIEW - Static variable in class org.infinispan.cacheviews.CacheView
 
EMPTY_CLASS_ARRAY - Static variable in class org.infinispan.util.ReflectionUtil
 
EMPTY_ENTRY_MAP - Static variable in class org.infinispan.context.impl.LocalTxInvocationContext
 
EMPTY_INJECT_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
EMPTY_OBJECT_ARRAY - Static variable in class org.infinispan.util.Util
 
EMPTY_PRIORITIZED_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
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
 
enable() - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
enable() - Method in interface org.infinispan.config.FluentConfiguration.VersioningConfig
Deprecated.  
enable() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
If true, all modifications to this cache store happen asynchronously, on a separate thread.
enable() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Enable deadlock detection
enable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Enable indexing
enable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Enable statistics gathering and reporting
enable() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Enable recovery for this cache
enable() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Enable the singleton store cache store
enable() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Enables storing both keys and values as binary.
enable() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
enableClasses(Class<?>[]) - Method in class org.infinispan.query.backend.QueryInterceptor
 
enabled - Variable in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
enabled(Boolean) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
enabled - Variable in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
enabled(Boolean) - Method in class org.infinispan.config.Configuration.InvocationBatching
Deprecated.  
enabled(Boolean) - Method in class org.infinispan.config.Configuration.JmxStatistics
Deprecated.  
enabled - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.  
enabled(Boolean) - Method in class org.infinispan.config.Configuration.LazyDeserialization
Deprecated.  
enabled - Variable in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
enabled(Boolean) - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
enabled - Variable in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
enabled(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.GroupsConfig
Deprecated. Enable grouping support, such that Group annotations are honoured and any configured groupers will be invoked
enabled - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
enabled(Boolean) - Method in class org.infinispan.config.GroupsConfiguration
Enable grouping support
enabled() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
If true, all modifications to this cache store happen asynchronously, on a separate thread.
enabled(boolean) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Whether deadlock detection is enabled or disabled
enabled(boolean) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Enable or disable deadlock detection
enabled() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
If grouping support is enabled, then Group annotations are honored and any configured groupers will be invoked
enabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Enable grouping support so that Group annotations are honored and any configured groupers will be invoked
enabled(boolean) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Enable grouping support so that Group annotations are honored and any configured groupers will be invoked
enabled() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Whether indexing is enabled.
enabled(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Enable or disable statistics gathering and reporting
enabled() - Method in class org.infinispan.configuration.cache.L1Configuration
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
Determines if recovery is enabled for the cache.
enabled(boolean) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Enable recovery for this cache
enabled() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
If true, the singleton store cache store is enabled.
enabled(boolean) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
If true, the singleton store cache store is enabled.
enabled() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Enables storing both keys and values as binary.
enabled(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Sets whether this feature is enabled or disabled.
enabled() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
enabled - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
enabled - Variable in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
enabled(Boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
If true, the singleton store cache store is enabled.
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.
enableOnRehash() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Entries removed due to a rehash will be moved to L1 rather than being removed altogether.
enableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Enable the background reaper to test entries for expiration.
ENCODE - Static variable in class org.infinispan.util.Base64
Specify encoding.
encodeBytes(byte[]) - Static method in class org.infinispan.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.infinispan.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int) - Static method in class org.infinispan.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.infinispan.util.Base64
Encodes a byte array into Base64 notation.
encodeFromFile(String) - Static method in class org.infinispan.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeObject(Serializable) - Static method in class org.infinispan.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.infinispan.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeToFile(byte[], String) - Static method in class org.infinispan.util.Base64
Convenience method for encoding data to a file.
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.CacheImpl
 
endElement(String, String, String) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
enlist(TxInvocationContext) - Method in class org.infinispan.interceptors.TxInterceptor
 
enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
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
 
EntityLoader - Class in org.infinispan.query.impl
 
EntityLoader(Cache<?, ?>, KeyTransformationHandler) - Constructor for class org.infinispan.query.impl.EntityLoader
 
entries - Variable in class org.infinispan.container.DefaultDataContainer
 
entryFactory - Variable in class org.infinispan.container.DefaultDataContainer
 
EntryFactory - Interface in org.infinispan.container
A factory for constructing MVCCEntry instances for use in the InvocationContext.
EntryFactoryImpl - Class in org.infinispan.container
EntryFactory implementation to be used for optimistic locking scheme.
EntryFactoryImpl() - Constructor for class org.infinispan.container.EntryFactoryImpl
 
EntryLookup - Interface in org.infinispan.context
Interface that can look up MVCC wrapped entries.
EntryMetaFactory - Class in org.infinispan.factories
 
EntryMetaFactory() - Constructor for class org.infinispan.factories.EntryMetaFactory
 
entrySet() - Method in class org.infinispan.AbstractDelegatingCache
 
entrySet() - Method in class org.infinispan.atomic.AtomicHashMap
 
entrySet() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
entrySet() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
entrySet() - Method in interface org.infinispan.Cache
Returns a set view of the mappings contained in this cache.
entrySet() - Method in class org.infinispan.CacheImpl
 
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() - Method in class org.infinispan.DecoratedCache
 
entrySet - Variable in class org.infinispan.util.AbstractMap
 
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.concurrent.ConcurrentWeakKeyHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
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
Command implementation for Map.entrySet() functionality.
EntrySetCommand(DataContainer, InternalEntryFactory) - Constructor for class org.infinispan.commands.read.EntrySetCommand
 
EntryVersion - Interface in org.infinispan.container.versioning
A version is used to compare entries against one another.
EntryVersionsMap - Class in org.infinispan.container.versioning
 
EntryVersionsMap() - Constructor for class org.infinispan.container.versioning.EntryVersionsMap
 
EntryWrappingInterceptor - Class in org.infinispan.interceptors
Interceptor in charge with wrapping entries and add them in caller's context.
EntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.EntryWrappingInterceptor
 
entryWrappingVisitor - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
EnumerationList<T> - Class in org.infinispan.util
An Enumeration -> List adaptor
EnumerationList(Enumeration<T>) - Constructor for class org.infinispan.util.EnumerationList
Constructor
eq(Object, Object) - Static method in class org.infinispan.util.AbstractMap
 
equals(Object) - Method in class org.infinispan.cacheviews.CacheView
 
equals(Object) - Method in class org.infinispan.cdi.interceptor.DefaultCacheKey
 
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.read.DistributedExecuteCommand
 
equals(Object) - Method in class org.infinispan.commands.read.MapReduceCommand
 
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.ApplyDeltaCommand
 
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.AdvancedExternalizerConfig
 
equals(Object) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
equals(Object) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration
Deprecated. Also see Configuration.equalsIgnoreName(Object) for equality that does not consider the name of the configuration.
equals(Object) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
equals(Object) - Method in class org.infinispan.config.CustomInterceptorConfig
 
equals(Object) - Method in class org.infinispan.config.GlobalConfiguration.AdvancedExternalizersType
Deprecated.  
equals(Object) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
equals(Object) - Method in class org.infinispan.config.GroupsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.AbstractTypedPropertiesConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AbstractLockSupportCacheStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AsyncConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.Configuration
 
equals(Object) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.EvictionConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.GroupsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.HashConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.IndexingConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.L1Configuration
 
equals(Object) - Method in class org.infinispan.configuration.cache.LoaderConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.LockingConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.SyncConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.VersioningConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
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.distexec.DefaultExecutorService.DistributedRunnableFuture
 
equals(Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
equals(Object) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.VirtualAddress
 
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.io.ExpandableMarshalledValueByteStream
 
equals(Object) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
equals(Object) - Method in class org.infinispan.io.GridFile
 
equals(Object) - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
 
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.ModificationsList
 
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.query.clustered.ClusteredQueryCommand
 
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.statetransfer.LockInfo
 
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.LocalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.RemoteTransaction
 
equals(Object) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
equals(Object) - Method in class org.infinispan.transaction.tm.DummyNoXaXid
 
equals(Object) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
equals(Object) - Method in class org.infinispan.transaction.tm.DummyXid
 
equals(Object) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
equals(Object) - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
equals(Object) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
 
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.concurrent.jdk8backported.ConcurrentHashMapV8
Compares the specified object with this map for equality.
equals(Object) - Method in class org.infinispan.util.ForwardingList
 
equals(Object) - Method in class org.infinispan.util.SimpleImmutableEntry
 
equalsExcludingProperties(Object) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
equalsIgnoreName(Object) - Method in class org.infinispan.config.Configuration
Deprecated. Same as Configuration.equals(Object) but it ignores the Configuration.getName() attribute in the comparison.
ERROR_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
errorBeforeReadingRequest(Throwable) - Method in interface org.infinispan.server.core.logging.JavaLog
 
errorChangingSingletonStoreStatus(SingletonStore.PushStateException) - Method in interface org.infinispan.util.logging.Log
 
errorClearinAsyncStore(CacheLoaderException) - Method in interface org.infinispan.util.logging.Log
 
errorClosingCatalog(Exception) - Method in interface org.infinispan.loaders.bdbje.logging.Log
 
errorClosingConnectionPool(Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorClosingDatabase(Exception) - Method in interface org.infinispan.loaders.bdbje.logging.Log
 
errorClosingSocket(TcpTransport, IOException) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorCommittingTx(XAException) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromConfigFile(String) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromConfigString(String) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromXML(String) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingTable(String, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
errorDetectingCrashedMember(Throwable) - Method in interface org.infinispan.server.hotrod.logging.JavaLog
 
errorDoingRemoteCall(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorDuringRehash(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorEnlistingResource(XAException) - Method in interface org.infinispan.util.logging.Log
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorFromServer(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorInstantiatingJdbcDriver(String, Exception) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorMarshallingBucket(IOException, Object) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
errorMarshallingObject(IOException) - Method in interface org.infinispan.util.logging.Log
 
errorModifyingAsyncStore(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorProcessing1pcPrepareCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessing2pcCommitCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorPurgingAsyncStore(CacheLoaderException) - Method in interface org.infinispan.util.logging.Log
 
errorPushingTxLog(ExecutionException) - Method in interface org.infinispan.util.logging.Log
 
errorReadingConfiguration(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorReadingFromFile(File, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorReadingProperties(IOException) - Method in interface org.infinispan.util.logging.Log
 
errorRemovingKey(Object, Exception) - Method in interface org.infinispan.loaders.cassandra.logging.Log
 
errorRequestingOrApplyingState(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorRollingBack(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorSavingBucket(Bucket, IOException) - Method in interface org.infinispan.util.logging.Log
 
errorSuspendingTransaction(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
errorTransferringState(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorTriggeringViewInstallation(RuntimeException, String) - Method in interface org.infinispan.util.logging.Log
 
errorUnblockingTransactions(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorWritingValueForAttribute(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
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<K,V> - 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<K,V> - 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.CacheImpl
 
evict(K) - Method in class org.infinispan.DecoratedCache
 
evict(Object) - Method in class org.infinispan.spring.provider.SpringCache
 
EvictCommand - Class in org.infinispan.commands.write
 
EvictCommand(Object, CacheNotifier) - Constructor for class org.infinispan.commands.write.EvictCommand
 
eviction() - Method in class org.infinispan.configuration.cache.Configuration
 
eviction() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
eviction() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
EVICTION_SCHEDULED_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
EvictionConfiguration - Class in org.infinispan.configuration.cache
Controls the eviction settings for the cache.
EvictionConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls the eviction settings for the cache.
evictionListener - Variable in class org.infinispan.container.DefaultDataContainer
 
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
 
evictionScheduledExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
evictionScheduledExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
evictionScheduledExecutor() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
EvictionStrategy - Enum in org.infinispan.eviction
Supported eviction strategies
EvictionThreadPolicy - Enum in org.infinispan.eviction
Supported eviction thread policy
evictionWakeUpIntervalDeprecated() - Method in interface org.infinispan.util.logging.Log
 
evictionWakeUpIntervalDeprecated(Long) - Method in interface org.infinispan.util.logging.Log
 
EXCEPTION_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
exceptionAndNoRetriesLeft(int, int, HotRodClientException) - Method in interface org.infinispan.client.hotrod.logging.Log
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.infinispan.server.websocket.WebSocketServerHandler
 
exceptionHandlingCommand(CacheRpcCommand, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionPurgingDataContainer(Exception) - Method in interface org.infinispan.util.logging.Log
 
exceptionReported(Throwable) - Method in interface org.infinispan.server.core.logging.JavaLog
 
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
 
exceptionWhenReplaying(WriteCommand, Exception) - Method in interface org.infinispan.util.logging.Log
 
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(Runnable) - Method in class org.infinispan.distexec.DefaultExecutorService
 
execute() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Executes this task across Infinispan cluster nodes.
execute(Collator<KOut, VOut, R>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Executes this task across Infinispan cluster but the final result is collated using specified Collator
execute(Runnable) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
execute(Runnable) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
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
 
executeAsynchronously() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Executes this task across Infinispan cluster nodes asynchronously.
executeAsynchronously(Collator<KOut, VOut, R>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Executes this task asynchronously across Infinispan cluster; final result is collated using specified Collator and wrapped by Future
executeFuture(Address, DefaultExecutorService.DistributedRunnableFuture<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
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.FaultTolerantPingOperation
 
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
 
executionError(Throwable) - Method in interface org.infinispan.util.logging.Log
 
executor - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
 
ExecutorFactory - Interface in org.infinispan.executors
Used to configure and create executors
ExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
 
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
Configures executor factory.
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
 
exists(AdvancedCache<?, ?>, Fqn) - Method in class org.infinispan.tree.TreeStructureSupport
 
ExpandableMarshalledValueByteStream - Class in org.infinispan.io
A byte stream that can be written to and expanded on the fly, not dissimilar to ExposedByteArrayOutputStream but with the benefit of not having to allocate unnecessary byte arrays byt not extending ByteArrayOutputStream.
ExpandableMarshalledValueByteStream() - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
 
ExpandableMarshalledValueByteStream(int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
 
ExpandableMarshalledValueByteStream(int, int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
expectedJustOneResponse(Map<Address, Response>) - Method in interface org.infinispan.util.logging.Log
 
ExperimentalDefaultConsistentHash - Class in org.infinispan.distribution.ch
Consistent hashing algorithm.
ExperimentalDefaultConsistentHash() - Constructor for class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
ExperimentalDefaultConsistentHash.Entry - Class in org.infinispan.distribution.ch
An entry into a consistent hash.
ExperimentalDefaultConsistentHash.Entry(Address, String, int, int) - Constructor for class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
ExperimentalDefaultConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
ExperimentalDefaultConsistentHash.Externalizer() - Constructor for class org.infinispan.di