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.distribution.ch.ExperimentalDefaultConsistentHash.Externalizer
 
expiration() - Method in class org.infinispan.configuration.cache.Configuration
 
expiration() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
expiration() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
ExpirationConfiguration - Class in org.infinispan.configuration.cache
Controls the default expiration settings for entries in the cache.
ExpirationConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls the default expiration settings for entries in the cache.
explain(int) - Method in interface org.infinispan.query.CacheQuery
Return the Lucene Explanation object describing the score computation for the matching object/document in the current query
explain(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
ExposedByteArrayOutputStream - Class in org.infinispan.io
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(byte[]) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
exposeJmxStats - Variable in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
EXTENDED_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
ExtendedModuleCommandFactory - Interface in org.infinispan.commands.module
Temporary workaround to avoid modifying ModuleCommandFactory interface.
ExtendedRiverMarshaller - Class in org.infinispan.marshall.jboss
RiverMarshaller extension that allows Infinispan code to directly create instances of it.
ExtendedRiverMarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.marshall.jboss.ExtendedRiverMarshaller
 
ExtendedRiverUnmarshaller - Class in org.infinispan.marshall.jboss
An extended RiverUnmarshaller that allows Infinispan StreamingMarshaller instances to travel down the stack to potential externalizer implementations that might need it, such as MarshalledValue.Externalizer
ExtendedRiverUnmarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.marshall.jboss.ExtendedRiverUnmarshaller
 
Externalizer<T> - Interface in org.infinispan.marshall
One of the key aspects of Infinispan is that it often needs to marshall or unmarshall objects in order to provide some of its functionality.
externalizerClass - Variable in class org.infinispan.config.AdvancedExternalizerConfig
 
ExternalizerIds - Interface in org.infinispan.lucene
Identifiers used by the Marshaller to delegate to specialized Externalizers.
ExternalizerTable - Class in org.infinispan.marshall.jboss
The externalizer table maintains information necessary to be able to map a particular type with the corresponding AdvancedExternalizer implementation that it marshall, and it also keeps information of which AdvancedExternalizer should be used to read data from a buffer given a particular AdvancedExternalizer identifier.
ExternalizerTable() - Constructor for class org.infinispan.marshall.jboss.ExternalizerTable
 
externalizerTypes - Variable in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
extractConfigurationDocComments(AnnotatedElement, Map<String, String>, ConfigurationDoc) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
extractFieldName(String) - Static method in class org.infinispan.util.ReflectionUtil
 
extractKey(DocumentExtractor, Cache<?, ?>, KeyTransformationHandler, int) - Static method in class org.infinispan.query.clustered.commandworkers.QueryExtractorUtil
 
extractProperties(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 

F

facet(XSFacet) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
factory(Class<? extends T>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.ExecutorFactoryConfig
Deprecated. Specify factory class for executor
factory - Variable in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
factory() - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
factory(Class<? extends ExecutorFactory>) - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
factory - Variable in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
factory() - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
factory(Class<? extends ScheduledExecutorFactory>) - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
factory() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
factory(ExecutorFactory) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
Specify factory class for executor NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
factory() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
factory(ScheduledExecutorFactory) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
Specify factory class for executor NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
factory - Variable in class org.infinispan.distexec.DefaultExecutorService
 
factory - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
failedAddingNewServer(SocketAddress, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
failedClearingJdbcCacheStore(Exception) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
failedClosingNamingCtx(NamingException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
failedInvalidatingRemoteCache(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingValueFromCacheStore(Object) - Method in interface org.infinispan.util.logging.Log
 
failedReplicatingQueue(int, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedSynchronizationRegistration(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToCallStopAfterFailure(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToCloseResource(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToCreateInitialCtx(NamingException) - Method in interface org.infinispan.util.logging.Log
 
failedToInvalidateKeys(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToUpdateAtribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
failureClosingConnection(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.TransactionTable
 
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
fallingBackToDummyTm() - Method in interface org.infinispan.util.logging.Log
 
FastCopyHashMap<K,V> - Class in org.infinispan.util
A HashMap that is optimized for fast shallow copies.
FastCopyHashMap(int, float) - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap(int) - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap() - Constructor for class org.infinispan.util.FastCopyHashMap
 
FastCopyHashMap.EntrySet - Class in org.infinispan.util
 
FastCopyHashMap.EntrySet() - Constructor for class org.infinispan.util.FastCopyHashMap.EntrySet
 
FastCopyHashMap.KeySet - Class in org.infinispan.util
 
FastCopyHashMap.KeySet() - Constructor for class org.infinispan.util.FastCopyHashMap.KeySet
 
FastCopyHashMap.Values - Class in org.infinispan.util
 
FastCopyHashMap.Values() - Constructor for class org.infinispan.util.FastCopyHashMap.Values
 
FaultTolerantPingOperation - Class in org.infinispan.client.hotrod.impl.operations
A fault tolerant ping operation that can survive to node failures.
FaultTolerantPingOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.FaultTolerantPingOperation
 
fclose(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Attempt to flush and close an OutputStream.
fclose(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to flush and close an array of OutputStreams.
fetchInMemoryState - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
fetchInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
fetchInMemoryState(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. If true, this will cause the cache to ask neighboring caches for state when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchInMemoryState() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
If true, the cache will fetch data from the neighboring caches when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchInMemoryState(boolean) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
If true, the cache will fetch data from the neighboring caches when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchPersistentState() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
If true, fetch persistent state when joining a cluster.
fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
If true, fetch persistent state when joining a cluster.
fetchPersistentState() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
Loops through all individual cache loader configs and checks if fetchPersistentState is set on any of them
fetchPersistentState - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
fetchPersistentState(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, fetch persistent state when joining a cluster.
fetchPersistentState(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
fetchPersistentState(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
fetchPersistentState(Boolean) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
fetchSize - Variable in class org.infinispan.query.impl.AbstractIterator
 
fetchValue(ClusteredDoc, ClusteredTopDocs) - Method in class org.infinispan.query.clustered.DistributedIterator
 
fetchValue(ClusteredDoc, ClusteredTopDocs) - Method in class org.infinispan.query.clustered.DistributedLazyIterator
 
fieldName - Variable in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
fieldNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
FILE - Static variable in class org.infinispan.io.GridFile.Metadata
 
FILE_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FILE_LIST_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FILE_METADATA - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FILE_READLOCK_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FileCacheKey - Class in org.infinispan.lucene
Used as a key for file headers in a cache
FileCacheKey(String, String) - Constructor for class org.infinispan.lucene.FileCacheKey
 
FileCacheKey.Externalizer - Class in org.infinispan.lucene
 
FileCacheKey.Externalizer() - Constructor for class org.infinispan.lucene.FileCacheKey.Externalizer
 
FileCacheStore - Class in org.infinispan.loaders.file
A filesystem-based implementation of a BucketBasedCacheStore.
FileCacheStore() - Constructor for class org.infinispan.loaders.file.FileCacheStore
 
FileCacheStore.NumericNamedFilesFilter - Class in org.infinispan.loaders.file
Makes sure that files opened are actually named as numbers (ignore all other files)
FileCacheStore.NumericNamedFilesFilter() - Constructor for class org.infinispan.loaders.file.FileCacheStore.NumericNamedFilesFilter
 
FileCacheStoreConfig - Class in org.infinispan.loaders.file
Configures FileCacheStore.
FileCacheStoreConfig() - Constructor for class org.infinispan.loaders.file.FileCacheStoreConfig
 
FileCacheStoreConfig.FsyncMode - Enum in org.infinispan.loaders.file
 
FileCacheStoreConfig.FsyncModeEditor - Class in org.infinispan.loaders.file
Property editor for fsync mode configuration.
FileCacheStoreConfig.FsyncModeEditor() - Constructor for class org.infinispan.loaders.file.FileCacheStoreConfig.FsyncModeEditor
 
FileCacheStoreConfiguration - Class in org.infinispan.configuration.cache
File cache store configuration.
FileCacheStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
File cache store configuration builder
FileCacheStoreConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
FileCacheStoreConfigurationBuilder.FsyncMode - Enum in org.infinispan.configuration.cache
 
fileExists(String) - Method in class org.infinispan.lucene.InfinispanDirectory
fileLength(String) - Method in class org.infinispan.lucene.InfinispanDirectory
FileListCacheKey - Class in org.infinispan.lucene
Cache key for a list with current files in cache
FileListCacheKey(String) - Constructor for class org.infinispan.lucene.FileListCacheKey
 
FileListCacheKey.Externalizer - Class in org.infinispan.lucene
 
FileListCacheKey.Externalizer() - Constructor for class org.infinispan.lucene.FileListCacheKey.Externalizer
 
FileLookup - Interface in org.infinispan.util
Holds the logic of looking up a file, in the following sequence:
FileLookupFactory - Class in org.infinispan.util
 
FileLookupFactory() - Constructor for class org.infinispan.util.FileLookupFactory
 
FileLookupFactory.DefaultFileLookup - Class in org.infinispan.util
 
FileLookupFactory.DefaultFileLookup() - Constructor for class org.infinispan.util.FileLookupFactory.DefaultFileLookup
 
FileMetadata - Class in org.infinispan.lucene
Header for Lucene files.
FileMetadata(int) - Constructor for class org.infinispan.lucene.FileMetadata
 
FileMetadata.Externalizer - Class in org.infinispan.lucene
 
FileMetadata.Externalizer() - Constructor for class org.infinispan.lucene.FileMetadata.Externalizer
 
fileModified(String) - Method in class org.infinispan.lucene.InfinispanDirectory
filename(String) - Static method in class org.infinispan.io.GridFile
 
FileReadLockKey - Class in org.infinispan.lucene
Lucene's index segment files are chunked, for safe deletion of elements a read lock is implemented so that all chunks are deleted only after the usage counter is decremented to zero.
FileReadLockKey(String, String) - Constructor for class org.infinispan.lucene.FileReadLockKey
 
FileReadLockKey.Externalizer - Class in org.infinispan.lucene
 
FileReadLockKey.Externalizer() - Constructor for class org.infinispan.lucene.FileReadLockKey.Externalizer
 
FilesystemDirectory - Class in org.infinispan.demos.directory
 
FilesystemDirectory() - Constructor for class org.infinispan.demos.directory.FilesystemDirectory
 
fillInStackTrace() - Method in exception org.infinispan.marshall.NotSerializableException
 
filter(Filter) - Method in interface org.infinispan.query.CacheQuery
Allows lucene to filter the results.
filter(Filter) - Method in class org.infinispan.query.impl.CacheQueryImpl
Takes in a lucene filter and sets it to the filter field in the class.
findComponentMetadata(Class<?>) - Static method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates metadata for a given component type if registered.
findComponentMetadata(String) - Static method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates metadata for a given component type if registered.
findDescription(AnnotatedElement) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
findDocElement(Class<?>, String) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
findFactoryForComponent(Class<?>) - Static method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates the fully qualified class name of a factory capable of constructing an instance of
findField(Class<?>, String) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
findGetterForField(Class<?>, String) - Static method in class org.infinispan.util.ReflectionUtil
 
findMethod(Class<?>, String) - Static method in class org.infinispan.util.ReflectionUtil
 
findMethod(Class<?>, String, Class<?>[]) - Static method in class org.infinispan.util.ReflectionUtil
 
findMethod(Class<?>, String, String[]) - Static method in class org.infinispan.util.ReflectionUtil
 
findNode(TreeNode, String, String) - Method in class org.infinispan.tools.doclet.config.XMLTreeOutputWalker
 
findSchemaInputStream() - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
findSchemaInputStream(String) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
findSetterForField(Class<?>, String) - Static method in class org.infinispan.util.ReflectionUtil
 
FineGrainedAtomicHashMapProxy<K,V> - Class in org.infinispan.atomic
A layer of indirection around an FineGrainedAtomicMap to provide consistency and isolation for concurrent readers while writes may also be going on.
FineGrainedAtomicMap<K,V> - Interface in org.infinispan.atomic
FineGrainedAtomicMap is a special type of Map geared for use in Infinispan.
finish() - Method in class org.infinispan.marshall.jboss.ExtendedRiverMarshaller
 
finish() - Method in class org.infinispan.marshall.jboss.ExtendedRiverUnmarshaller
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
finishObjectInput(ObjectInput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Finish using the given ObjectInput.
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Finish using the given ObjectOutput.
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
finishPushingState() - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
fire(T) - Method in class org.infinispan.cdi.event.cache.AbstractAdapter
 
fire(CacheEntryActivatedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryActivatedAdapter
 
fire(CacheEntryCreatedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryCreatedAdapter
 
fire(CacheEntryEvictedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryEvictedAdapter
 
fire(CacheEntryInvalidatedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryInvalidatedAdapter
 
fire(CacheEntryLoadedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryLoadedAdapter
 
fire(CacheEntryModifiedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryModifiedAdapter
 
fire(CacheEntryPassivatedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryPassivatedAdapter
 
fire(CacheEntryRemovedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryRemovedAdapter
 
fire(CacheEntryVisitedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.CacheEntryVisitedAdapter
 
fire(TransactionCompletedEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.TransactionCompletedAdapter
 
fire(TransactionRegisteredEvent<K, V>) - Method in class org.infinispan.cdi.event.cache.TransactionRegisteredAdapter
 
fire(T) - Method in class org.infinispan.cdi.event.cachemanager.AbstractAdapter
 
fire(CacheStartedEvent) - Method in class org.infinispan.cdi.event.cachemanager.CacheStartedAdapter
 
fire(CacheStoppedEvent) - Method in class org.infinispan.cdi.event.cachemanager.CacheStoppedAdapter
 
fire(ViewChangedEvent) - Method in class org.infinispan.cdi.event.cachemanager.ViewChangedAdapter
 
first() - Method in class org.infinispan.config.Configuration.CustomInterceptorPositionType
Deprecated.  
first() - Method in interface org.infinispan.config.FluentConfiguration.CustomInterceptorPosition
Deprecated.  
first() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
first - Variable in class org.infinispan.query.impl.AbstractIterator
 
first() - Method in class org.infinispan.query.impl.AbstractIterator
 
first() - Method in interface org.infinispan.query.QueryIterator
Jumps to the first result
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransactionManager
 
firstResult(int) - Method in interface org.infinispan.query.CacheQuery
Sets a result with a given index to the first result.
firstResult(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
Sets the the result of the given integer value to the first result.
Flag - Enum in org.infinispan.client.hotrod
Defines all the flags available in the Hot Rod client that can influence the behavior of operations.
Flag - Enum in org.infinispan.context
Available flags, which may be set on a per-invocation basis.
FLAG - Static variable in interface org.infinispan.marshall.Ids
 
Flag.Externalizer - Class in org.infinispan.context
 
Flag.Externalizer() - Constructor for class org.infinispan.context.Flag.Externalizer
 
FlagAffectedCommand - Interface in org.infinispan.commands
Commands affected by Flags should carry them over to the remote nodes.
flagContainer - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
FlagContainer - Interface in org.infinispan.context
Interface that defines access to and manipulation of Flag.
flags - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
flags(Flag[]) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
flags - Variable in class org.infinispan.commands.AbstractFlagAffectedCommand
 
flags - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
flags - Variable in class org.infinispan.context.impl.AbstractInvocationContext
 
floatValue() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
fluent() - Method in class org.infinispan.config.Configuration
Deprecated.  
fluent() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
FluentConfiguration - Class in org.infinispan.config
Deprecated. 
FluentConfiguration(Configuration) - Constructor for class org.infinispan.config.FluentConfiguration
Deprecated.  
FluentConfiguration.AsyncConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.ClusteringConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.CustomInterceptorCumulator - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.CustomInterceptorPosition - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.CustomInterceptorsConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.DataContainerConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.DeadlockDetectionConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.EvictionConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.ExpirationConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.GroupsConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.HashConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.IndexingConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.InvocationBatchingConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.JmxStatisticsConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.L1Config - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.LoadersConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.LockingConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.RecoveryConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.StateRetrievalConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.StoreAsBinaryConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.SyncConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.TransactionConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.UnsafeConfig - Interface in org.infinispan.config
Deprecated. 
FluentConfiguration.VersioningConfig - Interface in org.infinispan.config
Deprecated. 
FluentGlobalConfiguration - Class in org.infinispan.config
Deprecated. 
FluentGlobalConfiguration(GlobalConfiguration) - Constructor for class org.infinispan.config.FluentGlobalConfiguration
Deprecated.  
FluentGlobalConfiguration.ExecutorFactoryConfig<T> - Interface in org.infinispan.config
Deprecated. 
FluentGlobalConfiguration.GlobalJmxStatisticsConfig - Interface in org.infinispan.config
Deprecated. 
FluentGlobalConfiguration.SerializationConfig - Interface in org.infinispan.config
Deprecated. 
FluentGlobalConfiguration.ShutdownConfig - Interface in org.infinispan.config
Deprecated. 
FluentGlobalConfiguration.TransportConfig - Interface in org.infinispan.config
Deprecated. 
flush() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
flush() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
flush() - Method in class org.infinispan.io.GridOutputStream
 
flush() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
flush() - Method in class org.infinispan.io.WritableGridFileChannel
 
flush() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
flush() - Method in interface org.infinispan.remoting.ReplicationQueue
Flushes existing jobs in the replication queue, and returns the number of jobs flushed.
flush() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
flush(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Attempt to flush an OutputStream.
flush(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to flush an array of OutputStreams.
flushAndCloseOutput(ObjectOutput) - Static method in class org.infinispan.util.Util
 
flushAndCloseStream(OutputStream) - Static method in class org.infinispan.util.Util
 
flushBase64() - Method in class org.infinispan.util.Base64.OutputStream
Method added by PHIL.
flushCache(Collection<Object>, Object, Address, boolean) - Method in interface org.infinispan.distribution.L1Manager
Flushes a cache (using unicast or multicast) for a set of keys
flushCache(Collection<Object>, Object, Address, boolean) - Method in class org.infinispan.distribution.L1ManagerImpl
 
flushCacheWithSimpleFuture(Collection<Object>, Object, Address, boolean) - Method in interface org.infinispan.distribution.L1Manager
 
flushCacheWithSimpleFuture(Collection<Object>, Object, Address, boolean) - Method in class org.infinispan.distribution.L1ManagerImpl
 
flushLockTimeout() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
Timeout to acquire the lock which guards the state to be flushed to the cache store periodically.
flushLockTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
Timeout to acquire the lock which guards the state to be flushed to the cache store periodically.
flushLockTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
Timeout to acquire the lock which guards the state to be flushed to the cache store periodically.
flushLockTimeout - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
flushLockTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Timeout to acquire the lock which guards the state to be flushed to the cache store periodically.
FORCE_RETURN_VALUES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
forceCommit(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceCommit(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceLoad(Object, Set<Flag>) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
forceLoad(Object, Set<Flag>) - Method in class org.infinispan.interceptors.ClusteredActivationInterceptor
 
forceLoad(Object, Set<Flag>) - Method in class org.infinispan.interceptors.ClusteredCacheLoaderInterceptor
 
forceRollback(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceRollback(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceTransactionCompletion(Xid, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Replays the given transaction by re-running the prepare and commit.
forceTransactionCompletion(Xid, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
forceTransactionCompletionFromCluster(Xid, Address, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
This method invokes RecoveryManager.forceTransactionCompletion(javax.transaction.xa.Xid, boolean) on the specified node.
forceTransactionCompletionFromCluster(Xid, Address, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
forget(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forget(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forget(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
formatString(Object, Object...) - Static method in class org.infinispan.util.Util
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Element
 
forUri(String) - Static method in enum org.infinispan.configuration.parsing.Namespace
 
ForwardingList<E> - Class in org.infinispan.util
A list which forwards all its method calls to another list.
ForwardingList() - Constructor for class org.infinispan.util.ForwardingList
Constructor for use by subclasses.
Fqn - Class in org.infinispan.tree
A Fully Qualified Name (Fqn) is a list of names (typically Strings but can be any Object), which represent a path to a particular Node in a TreeCache.
Fqn.Externalizer - Class in org.infinispan.tree
 
Fqn.Externalizer() - Constructor for class org.infinispan.tree.Fqn.Externalizer
 
FqnComparator - Class in org.infinispan.tree
Compares the order of two FQN.
FqnComparator() - Constructor for class org.infinispan.tree.FqnComparator
 
frequency - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.  
friendlyCacheModeString() - Method in enum org.infinispan.configuration.cache.CacheMode
 
fromElements(Object...) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the array of elements passed in.
fromList(List<?>) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the list of elements passed in.
fromRelativeElements(Fqn, Object...) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the array of elements passed in, relative to the base Fqn.
fromRelativeFqn(Fqn, Fqn) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the absolute Fqn of the relative Fqn passed in.
fromRelativeList(Fqn, List<?>) - Static method in class org.infinispan.tree.Fqn
Retrieves an Fqn that represents the List of elements passed in, relative to the base Fqn.
fromStream(byte, Object[], String) - Method in interface org.infinispan.commands.module.ExtendedModuleCommandFactory
Construct and initialize a CacheRpcCommand based on the command id and argument array passed in.
fromStream(byte, Object[]) - Method in interface org.infinispan.commands.module.ModuleCommandFactory
Construct and initialize a ReplicableCommand based on the command id and argument array passed in.
fromStream(byte, Object[], byte) - Method in class org.infinispan.commands.RemoteCommandsFactory
Creates an un-initialized command.
fromStream(byte, Object[], byte, String) - Method in class org.infinispan.commands.RemoteCommandsFactory
Resolve an CacheRpcCommand from the stream.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Writes contents of the stream to the store.
fromStream(ObjectInput) - Method in interface org.infinispan.loaders.CacheStore
Writes contents of the stream to the store.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
Reads from a stream the number of entries (long) then the entries themselves.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Reads from a stream the number of entries (long) then the entries themselves.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
fromStream(byte, Object[], byte, String) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
fromStream(byte, Object[]) - Method in class org.infinispan.query.CommandFactory
 
fromStream(byte, Object[], String) - Method in class org.infinispan.query.CommandFactory
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
fromStreamProcess(Object, PreparedStatement, ObjectInput) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
fromStreamSupport(ObjectInput) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
fromString(String) - Method in class org.infinispan.query.DefaultTransformer
 
fromString(String) - Method in interface org.infinispan.query.Transformer
 
fromString(String) - Static method in class org.infinispan.tree.Fqn
Returns a new Fqn from a string, where the elements are deliminated by one or more separator (Fqn.SEPARATOR) characters.

Example use:
fsyncInterval() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
fsyncInterval(long) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
fsyncInterval(long) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
fsyncMode() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
fsyncMode(FileCacheStoreConfigurationBuilder.FsyncMode) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
fsyncMode(FileCacheStoreConfig.FsyncMode) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
futureDone(Future<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService.QueueingListener
 
futureDone(Future<T>) - Method in interface org.infinispan.util.concurrent.FutureListener
 
FutureListener<T> - Interface in org.infinispan.util.concurrent
A listener that is called back when a future is done.

G

generate() - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
generateCacheKey(CacheKeyInvocationContext<? extends Annotation>) - Method in class org.infinispan.cdi.interceptor.DefaultCacheKeyGenerator
 
generateContents() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
generateContents() - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
generateContents() - Method in class org.infinispan.tools.doclet.jmx.JmxHtmlGenerator
 
generateHeaderForConfigurationElement(StringBuilder, XMLTreeOutputWalker, TreeNode) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
generateHtml(String) - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
generateHtml(String, String) - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
generateNew() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
generateNew() - Method in interface org.infinispan.container.versioning.VersionGenerator
Generates a new entry version
generateRandomId() - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
generateTableRowForAttribute(XSAttributeDecl, StringBuilder, Object) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
GenericJBossMarshaller - Class in org.infinispan.marshall.jboss
A marshaller that makes use of JBoss Marshalling to serialize and deserialize objects.
GenericJBossMarshaller() - Constructor for class org.infinispan.marshall.jboss.GenericJBossMarshaller
 
GenericTransactionManagerLookup - Class in org.infinispan.transaction.lookup
A transaction manager lookup class that attempts to locate a TransactionManager.
GenericTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
get(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
get(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
get(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
get(Object) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
get(Object) - Method in class org.infinispan.CacheImpl
 
get() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
get(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
get(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
get(Object) - Method in interface org.infinispan.container.DataContainer
Retrieves a cached entry
get(Object) - Method in class org.infinispan.container.DefaultDataContainer
 
get(Object) - Method in class org.infinispan.DecoratedCache
 
get() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
get(long, TimeUnit) - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
get() - Method in class org.infinispan.marshall.MarshalledValue
Returns the 'cached' instance
get() - Method in class org.infinispan.nearcache.cdi.AddressController
 
get(Object) - Method in class org.infinispan.spring.provider.SpringCache
 
get(int) - Method in class org.infinispan.tree.Fqn
 
get(K) - Method in interface org.infinispan.tree.Node
Returns the value to which this node maps the specified key.
get(K, Flag...) - Method in interface org.infinispan.tree.Node
 
get(K) - Method in class org.infinispan.tree.NodeImpl
 
get(K, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
get(Fqn, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that allows for direct access to the data in a Node.
get(Fqn, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
get(String, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
get(String, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
get(Fqn, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(Fqn, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(String, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
get(String, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
get() - Method in class org.infinispan.util.ByRef
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
get() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
get() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
get(Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(Object) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
get(Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.NoOpFuture
 
get() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
get(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
get(int) - Method in class org.infinispan.util.ForwardingList
 
get(int) - Method in class org.infinispan.util.ImmutableListCopy
 
GET_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_VERSION - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_VERSION_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
getAbsoluteFile() - Method in class org.infinispan.io.GridFile
 
getAbsolutePath() - Method in class org.infinispan.io.GridFile
 
getActivations() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
getAddress() - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getAddress() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getAddress() - Method in class org.infinispan.manager.DefaultCacheManager
getAddress() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getAddress(String) - Method in class org.infinispan.nearcache.cdi.AddressDao
 
getAddress() - Method in class org.infinispan.query.clustered.QueryResponse
 
getAddress() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the address associated with this RpcManager or null if not part of the cluster.
getAddress() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getAddress() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's network address
getAddress() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
getAddress() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getAddress2KeysMapping() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getAdvancedCache() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getAdvancedCache() - Method in class org.infinispan.AbstractDelegatingCache
 
getAdvancedCache() - Method in interface org.infinispan.Cache
 
getAdvancedCache() - Method in class org.infinispan.CacheImpl
 
getAdvancedCache(BeanManager) - Method in class org.infinispan.cdi.AdvancedCacheProducer
 
getAdvancedExternalizer() - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
getAffectedKeys() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.write.ClearCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.write.PutMapCommand
 
getAffectedKeys() - Method in interface org.infinispan.commands.write.WriteCommand
 
getAffectedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getAffectedKeys() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the set of keys that are affected by this transaction.
getAffectedKeys() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
getAffectedKeys() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getAffectedNodes(Collection<Object>) - Method in interface org.infinispan.distribution.DistributionManager
A helper method that retrieves a list of nodes affected by operations on a set of keys.
getAffectedNodes(Collection<Object>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getAfter() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getAfterInterceptor() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getAllMethods(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllMethodsShallow(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllowDuplicateDomains() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
getAllowedMethodAnnotations() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getAllowedMethodAnnotations() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getAllowedMethodAnnotations() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getAllParameters() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getAncestor(int) - Method in class org.infinispan.tree.Fqn
Obtains an ancestor of the current Fqn.
getAnnotatedFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
 
getAnnotation(Class<?>, Class<T>) - Static method in class org.infinispan.util.ReflectionUtil
Inspects the class passed in for the class level annotation specified.
getAnnotations() - Method in class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
getAnnotations() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getAnnotations() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getAnnotations() - Method in class org.infinispan.cdi.interceptor.context.metadata.ParameterMetaData
 
getAsInputStreamFromClassLoader(String) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getAsInputStreamFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
 
getAsInputStreamFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.FileLookupFactory.DefaultFileLookup
 
getAsURLFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
 
getAsURLFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.FileLookupFactory.DefaultFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.FileLookupFactory.DefaultFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.util.OsgiFileLookup
 
getAsync(K) - Method in class org.infinispan.AbstractDelegatingCache
 
getAsync(K) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of Map.get(Object) that allows user code to retrieve the value associated with a key at a later stage, hence allowing multiple parallel get requests to be sent.
getAsync(K) - Method in class org.infinispan.CacheImpl
 
getAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getAsync(K) - Method in class org.infinispan.DecoratedCache
 
getAsyncExecutor() - Method in class org.infinispan.query.backend.QueryInterceptor
Use this executor for Async operations
getAsyncExecutorFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAsyncExecutorFactory() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
getAsyncListenerExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getAsyncListenerExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getAsyncResponseMode(Configuration) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Deprecated. 
getAsyncResponseMode(Configuration) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
 
getAsyncStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getAsyncStoreConfig() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getAsyncStoreConfig() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
getAsyncTransportExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getAsyncTransportExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key.
getAtomicMap(Cache<MK, ?>, MK, boolean) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key.
getAtomicMap(Cache<MK, ?>, MK, FlagContainer) - Static method in class org.infinispan.atomic.AtomicMapLookup
Deprecated. use AtomicMapLookup.getAtomicMap(org.infinispan.Cache, Object)
getAtomicMap(NodeKey) - Method in class org.infinispan.tree.TreeStructureSupport
 
getAtomicMap(AdvancedCache<?, ?>, NodeKey) - Method in class org.infinispan.tree.TreeStructureSupport
 
getAttribute(String) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributeMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributes() - Method in class org.infinispan.tools.schema.TreeNode
 
getAttributeValue(Element, String, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Retrieves the value of a given attribute for the first encountered instance of a tag in an element.
getAutoCommit() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getAvailability() - Method in class org.infinispan.rhq.CacheComponent
Return availability of this resource
getAvailability() - Method in class org.infinispan.rhq.CacheManagerComponent
Return availability of this resource.
getAverageReadTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAverageReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAverageWriteTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getBackupsForNode(Address, int) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
getBackupsForNode(Address, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated. No longer supported. This method doesn't make sense with virtual nodes enabled.
getBalancer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
Note that the returned RequestBalancingStrategy may not be thread-safe.
getBaseEvent() - Method in class org.infinispan.cdi.event.AbstractEventBridge
 
getBaseType() - Method in class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
getBaseType() - Method in class org.infinispan.cdi.interceptor.context.metadata.ParameterMetaData
 
getBatchContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getBatchContainer() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of batching cache operations.
getBatchContainer() - Method in class org.infinispan.CacheImpl
 
getBatchSize() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
getBatchSize() - Method in class org.infinispan.loaders.jdbc.TableManipulation
When doing repetitive DB inserts (e.g.
getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
 
getBeanClass() - Method in class org.infinispan.tools.schema.TreeNode
 
getBefore() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getBeforeInterceptor() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getBinaryCacheStore() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getBlockingCacheViewId() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
getBlockingCacheViewId() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getBooleanProperty(String, boolean, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.util.TypedProperties
 
getBooleanProperty(String, boolean, boolean) - Method in class org.infinispan.util.TypedProperties
 
getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
 
getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyXid
 
getBranchQualifier() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
 
getBucketId() - Method in class org.infinispan.loaders.bucket.Bucket
 
getBucketIdAsString() - Method in class org.infinispan.loaders.bucket.Bucket
 
getBucketPrefix() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getBuf() - Method in class org.infinispan.io.ByteBuffer
 
getBufferSize() - Method in class org.infinispan.lucene.FileMetadata
 
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
 
getBufferSizePredictor(Class<?>) - Method in class org.infinispan.marshall.MarshallableTypeHints
Get the serialized form size predictor for a particular type.
getBufferSizePredictor(Object) - Method in interface org.infinispan.marshall.Marshaller
Returns a marshalled payload size predictor for a particular type.
getBulk() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getBulk(int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getBulk() - Method in interface org.infinispan.client.hotrod.RemoteCache
Bulk get operations, returns all the entries within the remote cache.
getBulk(int) - Method in interface org.infinispan.client.hotrod.RemoteCache
Same as RemoteCache.getBulk(), but limits the returned set of values to the specified size.
getCache() - Method in interface org.infinispan.api.BasicCacheContainer
Retrieves the default cache associated with this cache container.
getCache(String) - Method in interface org.infinispan.api.BasicCacheContainer
Retrieves a named cache from the system.
getCache(String) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves a named cache from the remote server if the cache has been defined, otherwise if the cache name is underfined, it will return null.
getCache(String, boolean) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves the default cache from the remote server.
getCache(boolean) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache() - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
getCache() - Method in class org.infinispan.ec2demo.NucleotideCache
 
getCache() - Method in class org.infinispan.ec2demo.ProteinCache
 
getCache(String, boolean) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCache() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCache(String) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCache() - Method in interface org.infinispan.manager.CacheContainer
This method overrides the underlying CacheContainer.getCache(), to return a Cache instead of a BasicCache
getCache(String) - Method in interface org.infinispan.manager.CacheContainer
This method overrides the underlying CacheContainer.getCache(String), to return a Cache instead of a BasicCache
getCache() - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves the default cache associated with this cache manager.
getCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves a named cache from the system.
getCache(String, boolean) - Method in class org.infinispan.manager.DefaultCacheManager
 
getCache(String, boolean) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Retrieves a named cache from the system in the same way that CacheContainer.getCache(String) does except that if offers the possibility for the named cache not to be retrieved if it has not yet been started, or if it's been removed after being started.
getCache() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getCache() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getCache(String) - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
 
getCache(String) - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
 
getCache() - Method in interface org.infinispan.tree.TreeCache
 
getCache() - Method in class org.infinispan.tree.TreeCacheImpl
 
getCacheAnnotation() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getCacheAnnotation() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getCacheConfiguration() - Method in class org.infinispan.AbstractDelegatingCache
 
getCacheConfiguration() - Method in interface org.infinispan.Cache
 
getCacheConfiguration() - Method in class org.infinispan.CacheImpl
 
getCacheConfiguration(String) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCacheConfiguration(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheConfiguration(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns the configuration for the given cache.
getCacheDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getCacheDbNamePrefix() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getCachedValues() - Method in class org.infinispan.nearcache.cdi.AddressCacheManager
 
getCacheEntry() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
getCacheKeyGenerator() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getCacheKeyGenerator() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getCacheKeyGenerator(BeanManager, Class<? extends CacheKeyGenerator>, CacheDefaults) - Static method in class org.infinispan.cdi.util.CacheLookupHelper
Resolves and creates an instance of CacheKeyGenerator.
getCacheKeyInvocationContext(InvocationContext) - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextFactory
Returns the cache key invocation context corresponding to the given invocation context.
getCacheLoader() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
getCacheLoader() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
getCacheLoaderClassName() - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
getCacheLoaderClassName() - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
getCacheLoaderClassName() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
getCacheLoaderClassName() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
getCacheLoaderConfigs() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
getCacheLoaderLoads() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaderManagerConfig() - Method in class org.infinispan.config.Configuration
Deprecated. Use Configuration.getCacheLoaders(), Configuration.isCacheLoaderShared() Configuration.isFetchPersistentState(), Configuration.isCacheLoaderPassivation() and Configuration.isCacheLoaderPreload() instead
getCacheLoaderMisses() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaders() - Method in class org.infinispan.config.Configuration
Deprecated.  
getCacheLoaderStores() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
getCacheManager() - Method in class org.infinispan.AbstractDelegatingCache
 
getCacheManager() - Method in interface org.infinispan.Cache
Retrieves the cache manager responsible for creating this cache instance.
getCacheManager() - Method in class org.infinispan.CacheImpl
 
getCacheManager() - Method in class org.infinispan.demo.CacheBuilder
 
getCacheManager() - Method in class org.infinispan.ec2demo.CacheBuilder
 
getCacheManager() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getCacheManager() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getCacheManagerConfiguration() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCacheManagerConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheManagerConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns global configuration for this CacheManager
getCacheManagerName() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getCacheManagerName() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
getCacheManagerStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheMarshaller() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StreamingMarshaller.class, KnownComponentNames.CACHE_MARSHALLER);
getCacheMode() - Method in class org.infinispan.config.Configuration
Deprecated.  
getCacheModeString() - Method in class org.infinispan.config.Configuration
Deprecated.  
getCacheName() - Method in class org.infinispan.CacheImpl
Returns the cache name.
getCacheName() - Method in class org.infinispan.cacheviews.CacheViewInfo
 
getCacheName() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getCacheName() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getCacheName(Method, String, CacheDefaults, boolean) - Static method in class org.infinispan.cdi.util.CacheLookupHelper
Resolves the cache name of a method annotated with a JCACHE annotation.
getCacheName() - Method in interface org.infinispan.commands.CommandsFactory
Retrieves the cache name this CommandFactory is set up to construct commands for.
getCacheName() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
getCacheName() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
getCacheName() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
getCacheName() - Method in interface org.infinispan.commands.remote.CacheRpcCommand
 
getCacheName() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getCacheName() - Method in class org.infinispan.factories.ComponentRegistry
 
getCacheName() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
getCacheName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.CacheStartedEvent
 
getCacheName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.CacheStoppedEvent
 
getCacheName() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getCacheNames() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheNames() - Method in interface org.infinispan.manager.EmbeddedCacheManager
This method returns a collection of caches names which contains the caches that have been defined via XML or programmatically, and the caches that have been created at runtime via this cache manager instance.
getCacheNames() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
 
getCacheNames() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
As of Infinispan 4.2.0.FINAL org.infinispan.client.hotrod.RemoteCache does not support retrieving the set of all cache names from the hotrod server.
getCaches() - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
getCaches() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Should return a collection of cache addresses in the cluster.
getCaches() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
getCaches() - Method in class org.infinispan.distribution.ch.UnionConsistentHash
 
getCacheSize() - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
getCacheSize() - Method in class org.infinispan.ec2demo.NucleotideCache
 
getCacheSize() - Method in class org.infinispan.ec2demo.ProteinCache
 
getCacheStatus() - Method in class org.infinispan.CacheImpl
Returns String representation of ComponentStatus enumeration in order to avoid class not found exceptions in JMX tools that don't have access to infinispan classes.
getCacheStopTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.  
getCacheStopTimeout() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getCacheStore() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
getCacheStore() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
getCacheStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStore
 
getCacheStoreConfig() - Method in interface org.infinispan.loaders.CacheStore
Returns the configuration object associated to this cache store config.
getCacheStoreConfig() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
getCacheStoreConfig() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
getCacheStoreForStateTransfer() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
getCacheStoreForStateTransfer() - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
getCacheStoreForStateTransfer() - Method in class org.infinispan.statetransfer.DummyInvalidationStateTransferManagerImpl
Deprecated.  
getCacheStoreForStateTransfer() - Method in class org.infinispan.statetransfer.ReplicatedStateTransferManagerImpl
 
getCacheTransaction() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getCacheTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getCacheTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getCacheTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
 
getCacheTransaction() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
getCatalogDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getChangeLogSize() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getChild(Fqn) - Method in interface org.infinispan.tree.Node
Returns the child node
getChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
getChild(Object) - Method in interface org.infinispan.tree.Node
 
getChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
getChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
getChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
getChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChildren() - Method in class org.infinispan.tools.schema.TreeNode
 
getChildren() - Method in interface org.infinispan.tree.Node
Returns an immutable set of children nodes.
getChildren(Flag...) - Method in interface org.infinispan.tree.Node
 
getChildren() - Method in class org.infinispan.tree.NodeImpl
 
getChildren(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChildrenNames(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
getChildrenNames() - Method in interface org.infinispan.tree.Node
Returns an immutable set of children node names.
getChildrenNames(Flag...) - Method in interface org.infinispan.tree.Node
 
getChildrenNames() - Method in class org.infinispan.tree.NodeImpl
 
getChildrenNames(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getChunkId() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the chunkId.
getChunkSize() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getChunkSize() - Method in class org.infinispan.io.GridFile
 
getChunkSize() - Method in class org.infinispan.io.GridFile.Metadata
 
getClassForName(String, ClassLoader) - Static method in class org.infinispan.util.ReflectionUtil
 
getClassLoader() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getClassLoader() - Method in interface org.infinispan.AdvancedCache
Returns the cache loader associated associated with this cache.
getClassLoader() - Method in class org.infinispan.CacheImpl
 
getClassLoader() - Method in class org.infinispan.ClassLoaderSpecfiedCache
 
getClassLoader() - Method in class org.infinispan.config.Configuration
Deprecated.  
getClassLoader() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Get the classloader in use by this configuration.
getClassLoader() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
getClassLoader() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
getClassLoader() - Method in class org.infinispan.context.impl.ImmutableContext
 
getClassLoader() - Method in interface org.infinispan.context.InvocationContext
Returns the class loader associated with this invocation
getClassLoader() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
getClassLoader() - Method in class org.infinispan.DecoratedCache
 
getClassLoader() - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
getClassLoader() - Method in interface org.infinispan.loaders.CacheLoaderConfig
Get the classloader that should be used to load resources from the classpath
getClassLoader() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
getClassLoader() - Method in class org.infinispan.marshall.jboss.DefaultContextClassResolver
 
getClassLoader() - Method in class org.infinispan.marshall.jboss.JBossMarshaller.EmbeddedContextClassResolver
 
getClassLoaders(ClassLoader) - Static method in class org.infinispan.util.Util
 
getClassMapping(String) - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getClassMappings() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getClassName() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getClassResolver() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getClazz() - Method in class org.infinispan.config.GrouperConfiguration
 
getClazz() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getCloudService() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getCloudServiceLocation() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getClusteredDefault(ClassLoader) - Static method in class org.infinispan.config.GlobalConfiguration
Deprecated. Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
getClusteredDefault() - Static method in class org.infinispan.config.GlobalConfiguration
Deprecated. Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
getClusteredQuery(Query, Class<?>...) - Method in interface org.infinispan.query.SearchManager
Experimental! Use it to try out the newly introduced distributed queries.
getClusterMembers() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterName() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getClusterName() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getClusterName() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getClusterName() - Method in class org.infinispan.manager.DefaultCacheManager
getClusterName() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClusterSize() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCode() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getCodec(String) - Static method in class org.infinispan.client.hotrod.impl.protocol.CodecFactory
 
getCoinToss() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
getCollocatedKey(K) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the same node as the supplied key.
getCollocatedKey(K) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getColumnCount() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getColumnCount() - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getColumnName(int) - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getColumnName(int) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getCommand() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommand() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
getCommand(Cache<?, ?>, HSQuery, UUID, int) - Method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
 
getCommandAwareRpcDispatcher() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCommandId() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
getCommandId() - Method in class org.infinispan.commands.control.LockControlCommand
 
getCommandId() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getCommandId() - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
getCommandId() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.read.MapReduceCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommandId() - Method in class org.infinispan.commands.RemoveCacheCommand
 
getCommandId() - Method in interface org.infinispan.commands.ReplicableCommand
Used by marshallers to convert this command into an id for streaming.
getCommandId() - Method in class org.infinispan.commands.tx.CommitCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.RollbackCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ClearCommand
 
getCommandId() - Method in class org.infinispan.commands.write.EvictCommand
 
getCommandId() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getCommandId() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
getCommandId() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.write.PutMapCommand
 
getCommandId() - Method in class org.infinispan.commands.write.RemoveCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getCommandId() - Method in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
getCommandId() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
getCommands() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getCommandsFactory() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getLocalComponent(CommandsFactory.class);
getCommits() - Method in class org.infinispan.interceptors.TxInterceptor
 
getCommittedView() - Method in class org.infinispan.cacheviews.CacheViewInfo
 
getCommittedView(String) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
getCommittedView(String) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
getCommittedViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getComparatorClassName() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
getComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component of a specified type from the registry, or null if it cannot be found.
getComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getComponent(String, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getComponent(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getComponent(String, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getComponent(Cache<?, ?>, Class<T>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getComponentRegistry() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getComponentRegistry() - Method in interface org.infinispan.AdvancedCache
 
getComponentRegistry() - Method in class org.infinispan.CacheImpl
 
getCompositeKeys() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getConcurrencyLevel() - Method in class org.infinispan.config.Configuration
Deprecated.  
getConcurrencyLevel() - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
getConcurrencyLevel() - Method in class org.infinispan.loaders.AbstractCacheStore
 
getConcurrencyLevel() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getConfigBeans() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getConfigBeans() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
getConfiguration() - Method in class org.infinispan.AbstractDelegatingCache
 
getConfiguration() - Method in interface org.infinispan.Cache
Deprecated. 
getConfiguration() - Method in class org.infinispan.CacheImpl
Deprecated. 
getConfiguration() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getConfiguration(String) - Method in interface org.infinispan.config.ConfigurationRegistry
Gets a clone of the Configuration registered under the given name.
getConfiguration() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the configuration component.
getConfiguration() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
getConfigurationAsXmlString() - Method in class org.infinispan.CacheImpl
Returns the cache configuration as XML string.
getConfigurationClass() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
This method is used by the configuration parser to get a hold of the CacheLoader implementation's corresponding CacheLoaderConfig type.
getConfigurationClass() - Method in interface org.infinispan.loaders.CacheLoader
This method is used by the configuration parser to get a hold of the CacheLoader implementation's corresponding CacheLoaderConfig type.
getConfigurationClass() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
getConfigurationClass() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.file.FileCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
getConfigurationClass() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
getConfigurationNames() - Method in interface org.infinispan.config.ConfigurationRegistry
Gets the names of all registered configurations.
getConfigurationPropertiesFile() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Fetches a connection from the factory.
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
getConnection() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getConnectionFactory() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getConnectionFactory(String, ClassLoader) - Static method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Constructs a ConnectionFactory based on the supplied class name.
getConnectionFactory() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getConnectionFactory() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getConnectionFactoryClass() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionFactoryConfig() - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
getConnectionPool() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConnectionUrl() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionUrl() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getConnectTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConnectTimeout() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConnectTimeout() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getConsistentHash() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
Note that the returned ConsistentHash may not be thread-safe.
getConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
Retrieves the consistent hash instance currently in use, an instance of the configured ConsistentHash class (which defaults to DefaultConsistentHash.
getConsistentHash() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getConsistentHashAtStart() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getConsistentHashClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
getConsistentHashClass() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
getConsistentHashFactory() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConsistentHashFactory() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getContents() - Method in class org.infinispan.tree.NodeKey
 
getCoordinator() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
getCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
getCountry() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getCreated() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getCreated() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
getCreated() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getCreatedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCurrentNumberOfEntries() - Method in interface org.infinispan.stats.Stats
Returns the number of entries currently in this cache instance.
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.StatsImpl
 
getCustomInterceptors() - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
getCustomInterceptors() - Method in class org.infinispan.config.Configuration
Deprecated. Returns the CustomInterceptorConfig, if any, associated with this configuration object.
getCustomInterceptorsBuilder() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
getData() - Method in interface org.infinispan.tree.Node
Returns a map containing the data in this Node.
getData(Flag...) - Method in interface org.infinispan.tree.Node
 
getData() - Method in class org.infinispan.tree.NodeImpl
 
getData(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getData(Fqn) - Method in interface org.infinispan.tree.TreeCache
Retrieves a defensively copied data map of the underlying node.
getData(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getData(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
getData(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getData() - Method in class org.infinispan.util.ByteArrayKey
 
getDatabaseType() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
getDatabaseType() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
getDataColumnName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDataColumnType() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDataContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getDataContainer() - Method in interface org.infinispan.AdvancedCache
Returns the container where data is stored in the cache.
getDataContainer() - Method in class org.infinispan.CacheImpl
 
getDataContainer() - Method in class org.infinispan.config.Configuration
Deprecated.  
getDataContainerClass() - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
getDataContainerClass() - Method in class org.infinispan.config.Configuration
Deprecated. Pluggable data container class which must implement DataContainer
getDataContainerProperties() - Method in class org.infinispan.config.Configuration
Deprecated.  
getDatasourceJndiLocation() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getDatasourceJndiLocation() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getDeadlockDetectionSpinDuration() - Method in class org.infinispan.config.Configuration
Deprecated.  
getDecoder() - Method in class org.infinispan.server.websocket.WebSocketServer
 
getDefaultCacheConfiguration() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getDefaultCacheConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefaultCacheConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns default configuration for this CacheManager
getDefaultConfiguration() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getDefaultConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefaultConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated. 
getDefaultConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getDefaultEmbeddedCacheConfiguration(Instance<Configuration>) - Method in class org.infinispan.cdi.DefaultEmbeddedCacheConfigurationProducer
Produces the default embedded cache configuration.
getDefaultEmbeddedCacheManager(Instance<EmbeddedCacheManager>, Configuration) - Method in class org.infinispan.cdi.DefaultEmbeddedCacheManagerProducer
Produces the default embedded cache manager.
getDefaultExecutorFactoryPoolSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultExecutorFactoryQueueSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultRemoteCacheManager() - Method in class org.infinispan.cdi.DefaultRemoteCacheManagerProducer
Produces the default remote cache manager with the default settings.
getDefaultScope() - Static method in enum org.infinispan.factories.scopes.Scopes
 
getDefaultThreadPrio(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultThreads(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefinedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDelegate() - Method in class org.infinispan.AbstractDelegatingCache
 
getDelegate() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
getDeleteAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDeleteExpiredRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDeleteRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getDelta() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getDeltaAwareKey() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getDeltaMapForRead() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
getDeltaMapForWrite() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
getDeltaMapForWrite() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
getDependencies() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getDepth() - Method in class org.infinispan.tools.schema.TreeNode
 
getDescription() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
getDescription() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getDescription() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getDetectedLocalDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getDetectedRemoteDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getDistance(Address, Address) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
The distance between the first entries in the address array for two caches, a1 and a2.
getDistributedSyncTimeout() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getDistributedSyncTimeout() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getDistributionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getDistributionManager() - Method in interface org.infinispan.AdvancedCache
Retrieves a reference to the DistributionManager if the cache is configured to use Distribution.
getDistributionManager() - Method in class org.infinispan.CacheImpl
 
getDocumentRoot(InputStream) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns the root element of a given input stream
getDriverClass() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getElapsedTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getElementContent(Element, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of the element passed in.
getElementsCount() - Method in interface org.infinispan.remoting.ReplicationQueue
 
getElementsCount() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
getEmsConnection() - Method in class org.infinispan.rhq.CacheManagerComponent
 
getEnabled() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
getEncoder() - Method in class org.infinispan.server.websocket.WebSocketServer
 
getEnlistedResources() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getEnlistedSynchronization() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getEntries() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntriesEvictedEvent
Retrieves entries being evicted.
getEntries() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getEntry(Object) - Method in class org.infinispan.loaders.bucket.Bucket
 
getEntryColumnFamily() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getEnvironmentPropertiesFile() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getErroneousAttributes() - Method in exception org.infinispan.CacheConfigurationException
 
getErroneousAttributes() - Method in exception org.infinispan.config.ConfigurationException
 
getEvictionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getEvictionManager() - Method in interface org.infinispan.AdvancedCache
 
getEvictionManager() - Method in class org.infinispan.CacheImpl
 
getEvictionMaxEntries() - Method in class org.infinispan.config.Configuration
Deprecated.  
getEvictions() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getEvictions() - Method in interface org.infinispan.stats.Stats
 
getEvictions() - Method in class org.infinispan.stats.StatsImpl
 
getEvictionScheduledExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getEvictionScheduledExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getEvictionStrategy() - Method in class org.infinispan.config.Configuration
Deprecated.  
getEvictionThreadPolicy() - Method in class org.infinispan.config.Configuration
Deprecated.  
getEvictionWakeUpInterval() - Method in class org.infinispan.config.Configuration
Deprecated. Use Configuration.getExpirationWakeUpInterval()
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getExecutor(Properties) - Method in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in interface org.infinispan.executors.ExecutorFactory
 
getExpirationColumnFamily() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getExpirationLifespan() - Method in class org.infinispan.config.Configuration
Deprecated. Expiration lifespan, in milliseconds
getExpirationMaxIdle() - Method in class org.infinispan.config.Configuration
Deprecated. Expiration max idle time, in milliseconds
getExpirationWakeUpInterval() - Method in class org.infinispan.config.Configuration
Deprecated. Eviction thread wake up interval, in milliseconds.
getExpiryDbName() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getExpiryDbPrefix() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getExpiryQueueSize() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
getExpiryTime() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getExpiryTime() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Only used with entries that have a lifespan, this determines when an entry is due to expire.
getExpiryTime() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getExternalizer(Class<?>) - Method in class org.infinispan.marshall.jboss.SerializeWithExtFactory
 
getExternalizerClass() - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
getExternalizers() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getFacetManager() - Method in interface org.infinispan.query.CacheQuery
 
getFacetManager() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
getFactory() - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated. 
getFactory() - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated. 
getFactory(Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component factory instance capable of constructing components of a specified type.
getFetchedValue() - Method in class org.infinispan.query.clustered.QueryResponse
 
getFetchSize() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
getFetchSize() - Method in class org.infinispan.loaders.jdbc.TableManipulation
For DB queries (e.g.
getField(String, Class<?>) - Static method in class org.infinispan.util.ReflectionUtil
 
getFieldName() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
getFields(Class<?>, Class<?>) - Static method in class org.infinispan.util.ReflectionUtil
 
getFile(String) - Method in class org.infinispan.io.GridFilesystem
Returns the file denoted by pathname.
getFile(String, int) - Method in class org.infinispan.io.GridFilesystem
Returns the file denoted by pathname.
getFile(String, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(String, String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFileName() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the fileName.
getFileName() - Method in class org.infinispan.lucene.FileCacheKey
Get the fileName.
getFileName() - Method in class org.infinispan.lucene.FileReadLockKey
Get the fileName.
getFilePointer() - Method in class org.infinispan.lucene.InfinispanIndexInput
 
getFilePointer() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
getFilePointer() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
getFineGrainedAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves a fine grained atomic map from a given cache, stored under a given key.
getFineGrainedAtomicMap(Cache<MK, ?>, MK, boolean) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key.
getFirstCacheLoaderConfig() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
getFirstChildElement(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Gets the first child element of an element
getFirstInChain() - Method in class org.infinispan.interceptors.InterceptorChain
 
getFlagInt() - Method in enum org.infinispan.client.hotrod.Flag
 
getFlags() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
getFlags() - Method in class org.infinispan.commands.control.LockControlCommand
 
getFlags() - Method in interface org.infinispan.commands.FlagAffectedCommand
 
getFlags() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getFlags() - Method in interface org.infinispan.context.FlagContainer
 
getFlags() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
getFlags() - Method in class org.infinispan.context.impl.ImmutableContext
 
getFlags() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
getFlags() - Method in class org.infinispan.DecoratedCache
 
getFlags() - Method in class org.infinispan.tree.TreeContext
 
getFlushLockTimeout() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getForceReturnValues() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getFormatId() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
 
getFormatId() - Method in class org.infinispan.transaction.tm.DummyXid
 
getFormatId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
 
getFqn() - Method in interface org.infinispan.tree.Node
Returns the Fqn which represents the location of this Node in the cache structure.
getFqn() - Method in class org.infinispan.tree.NodeImpl
 
getFqn() - Method in class org.infinispan.tree.NodeKey
 
getFsyncInterval() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getFsyncMode() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getFullLengthSequence() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getGanNucleoid() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
getGenbankAccessionNumber() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getGenomeSequenceNumber() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getGlobalComponentRegistry() - Method in class org.infinispan.factories.ComponentRegistry
 
getGlobalConfiguration() - Method in class org.infinispan.config.Configuration
Deprecated.  
getGlobalConfiguration() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getGlobalConfiguration() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getGlobalConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getGlobalConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns global configuration for this CacheManager
getGlobalConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getGlobalTransaction() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getGlobalTransaction() - Method in interface org.infinispan.commands.tx.TransactionBoundaryCommand
 
getGlobalTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getGlobalTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getGlobalTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the id of the transaction associated with the current call.
getGlobalTransaction() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
getGlobalTransaction() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getGlobalTransaction() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
 
getGlobalTransaction() - Method in class org.infinispan.statetransfer.LockInfo
 
getGlobalTransaction() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getGlobalTransaction() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the transaction identifier.
getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
 
getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyXid
 
getGlobalTransactionId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
 
getGroup(Object) - Method in interface org.infinispan.distribution.group.GroupManager
Get the group for a given key
getGroup(Object) - Method in class org.infinispan.distribution.group.GroupManagerImpl
 
getGroupers() - Method in class org.infinispan.config.Configuration
Deprecated.  
getGroupers() - Method in interface org.infinispan.config.FluentConfiguration.GroupsConfig
Deprecated. Get's the current groupers in use
getGroupers() - Method in class org.infinispan.config.GroupsConfiguration
 
getGroupGeneratorConfigurations() - Method in class org.infinispan.config.GroupsConfiguration
 
getGrouping(Object) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
Get the grouping, if any, for this key.
getGroups() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
GetHandler - Class in org.infinispan.server.websocket.handlers
Cache "get" operation handler.
GetHandler() - Constructor for class org.infinispan.server.websocket.handlers.GetHandler
 
getHashFunctionClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
getHashFunctionClass() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
getHashIds(Address) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
getHashIds(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns a list of values between 0 and the hash space limit, or hash id, for a particular address.
getHashIds(Address) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
getHashIds(Address) - Method in class org.infinispan.distribution.ch.UnionConsistentHash
 
getHitRatio() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getHits() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getHits() - Method in interface org.infinispan.stats.Stats
 
getHits() - Method in class org.infinispan.stats.StatsImpl
 
getHoldCount(Object) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
getHookBehavior() - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
Deprecated.  
getHost() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getHost() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getHostAge() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getHostGender() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getHostName() - Method in interface org.infinispan.server.core.transport.Transport
 
getHotRodClientProperties() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
getId() - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
getId() - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
getId() - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
getId() - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
getId() - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
getId() - Method in class org.infinispan.cacheviews.CacheView.Externalizer
 
getId() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash2.Externalizer
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash2Compat.Externalizer
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
getId() - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
getId() - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.context.Flag.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.UnionConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.VirtualAddress
 
getId() - Method in class org.infinispan.distribution.RemoteTransactionLogDetails.Externalizer
 
getId() - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
getId() - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
getId() - Method in class org.infinispan.marshall.AbstractExternalizer
 
getId() - Method in interface org.infinispan.marshall.AdvancedExternalizer
Returns an integer that identifies the externalizer type.
getId() - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.LinkedListExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MapExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.SetExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.SingletonListExternalizer
 
getId() - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
getId() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getId() - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
getId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
getId() - Method in class org.infinispan.statetransfer.LockInfo.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getId() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
 
getId() - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
getId() - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
getIdColumnName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getIdColumnType() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getIdentifierQuoteString() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getIdentity() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getIdleTimeout() - Method in interface org.infinispan.server.core.transport.Transport
 
getIndex() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getIndex() - Method in interface org.infinispan.query.clustered.ClusteredDoc
 
getIndex() - Method in class org.infinispan.query.clustered.ClusteredFieldDoc
 
getIndex() - Method in class org.infinispan.query.clustered.ClusteredScoreDoc
 
getIndexingProperties() - Method in class org.infinispan.config.Configuration
Deprecated.  
getIndexName() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileListCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileReadLockKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.InfinispanDirectory
 
getInDoubtTransactionInfo() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Same as RecoveryManager.getInDoubtTransactionInfoFromCluster(), but only returns transactions from the local node.
getInDoubtTransactionInfo() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getInDoubtTransactionInfoFromCluster() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Returns a Set containing all the in-doubt transactions from the cluster, including the local node.
getInDoubtTransactionInfoFromCluster() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getInDoubtTransactions() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Local call that returns a list containing:
getInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
GetInDoubtTransactionsCommand - Class in org.infinispan.commands.remote.recovery
Rpc to obtain all in-doubt prepared transactions stored on remote nodes.
GetInDoubtTransactionsCommand(String) - Constructor for class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
getInDoubtTransactionsMap() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
GetInDoubtTxInfoCommand - Class in org.infinispan.commands.remote.recovery
Command used by the recovery tooling for obtaining the list of in-doubt transactions from a node.
GetInDoubtTxInfoCommand(String) - Constructor for class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
getInfinispanMarshaller() - Method in class org.infinispan.marshall.jboss.ExtendedRiverUnmarshaller
 
getInitialRetryWaitTime() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getInjectMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getInput(String) - Method in class org.infinispan.io.GridFilesystem
Opens an InputStream for reading from the file denoted by pathname.
getInput(File) - Method in class org.infinispan.io.GridFilesystem
Opens an InputStream for reading from the given file.
getInsertRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getInstance() - Static method in class org.infinispan.container.entries.NullMarkerEntry
 
getInstance() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getInstance(ComponentRegistry, Configuration) - Static method in class org.infinispan.factories.InterceptorChainFactory
 
getInstance(AdvancedCache<?, ?>) - Static method in class org.infinispan.query.backend.KeyTransformationHandler
Gets the KeyTransformationHandler instance used by the supplied cache.
getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
getInstance() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getInstance(Class<T>) - Static method in class org.infinispan.util.Util
Instantiates a class by first attempting a static factory method named getInstance() on the class and then falling back to an empty constructor.
getInstance(String, ClassLoader) - Static method in class org.infinispan.util.Util
Instantiates a class based on the class name provided.
getInstanceStrict(Class<T>) - Static method in class org.infinispan.util.Util
Similar to Util.getInstance(Class) except that exceptions are propagated to the caller.
getInstanceStrict(String, ClassLoader) - Static method in class org.infinispan.util.Util
Similar to Util.getInstance(String, ClassLoader) except that exceptions are propagated to the caller.
getInterceptor() - Method in class org.infinispan.config.CustomInterceptorConfig
Returns a the interceptor that we want to add to the chain.
getInterceptorChain() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getInterceptorChain() - Method in interface org.infinispan.AdvancedCache
Retrieves the current Interceptor chain.
getInterceptorChain() - Method in class org.infinispan.CacheImpl
 
getInterceptorsWhichExtend(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Returns all interceptors which extend the given command interceptor.
getInterceptorsWithClassName(String) - Method in class org.infinispan.interceptors.InterceptorChain
Returns all the interceptors that have the fully qualified name of their class equal with the supplied class name.
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
getInternalId() - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
 
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
getInternalId() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
Each xid has a unique long object associated to it.
getIntProperty(String, int) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getIntProperty(String, int) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getIntProperty(String, int) - Method in class org.infinispan.util.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.util.TypedProperties
 
getIntStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getIntStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getInvalidations() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getInvalidationThreshold() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
getInvocationContext(boolean) - Method in class org.infinispan.context.AbstractInvocationContextContainer
 
getInvocationContext(boolean) - Method in interface org.infinispan.context.InvocationContextContainer
Deprecated. see implementation for notes
getInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
getInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
getInvocationContextContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getInvocationContextContainer() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of managing the interactions between the cache operations and the context information associated with them.
getInvocationContextContainer() - Method in class org.infinispan.CacheImpl
 
getIsolationLevel() - Method in class org.infinispan.config.Configuration
Deprecated.  
getIsolationLevel() - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
getJavascript() - Static method in class org.infinispan.server.websocket.WebSocketServer
 
getJAXBContext() - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Returns the JAXB context that may be used to read and write Infinispan configurations.
getJGroupsAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
getJGroupsChannel(Properties) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
Retrieves a JGroups channel.
getJmxDomain() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getJmxDomain() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
getJmxObjectName() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getKey() - Method in interface org.infinispan.affinity.KeyGenerator
 
getKey() - Method in class org.infinispan.affinity.RndKeyGenerator
 
getKey() - Method in interface org.infinispan.commands.DataCommand
 
getKey() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getKey() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getKey() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getKey() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKey() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getKey() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the key to this entry
getKey() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getKey() - Method in class org.infinispan.loaders.modifications.Remove
 
getKey() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
getKey() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getKey() - Method in class org.infinispan.statetransfer.LockInfo
 
getKey() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
getKey() - Method in class org.infinispan.util.SimpleImmutableEntry
 
getKey2StringMapper() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
getKeyForAddress(Address) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the cluster node identified by address.
getKeyForAddress(Address) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getKeyMapper() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getKeyMapping(String) - Method in class org.infinispan.loaders.keymappers.DefaultTwoWayKey2StringMapper
 
getKeyMapping(String) - Method in interface org.infinispan.loaders.keymappers.TwoWayKey2StringMapper
Maps a String back to its original key
getKeyMapping(String) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
This method has to perform the inverse transformation of the keys used in the Lucene Directory from String to object.
getKeyParameters() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getKeyParameters() - Method in class org.infinispan.cdi.interceptor.context.metadata.AggregatedParameterMetaData
 
getKeyParameters() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getKeys() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getKeys() - Method in class org.infinispan.commands.control.LockControlCommand
 
getKeys() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getKeys() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKeys() - Method in interface org.infinispan.tree.Node
Returns a Set containing the data in this Node.
getKeys(Flag...) - Method in interface org.infinispan.tree.Node
 
getKeys() - Method in class org.infinispan.tree.NodeImpl
 
getKeys(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getKeys(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes in a String represenation of the Fqn.
getKeys(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getKeys(Fqn) - Method in interface org.infinispan.tree.TreeCache
Returns a set of attribute keys for the Fqn.
getKeys(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getKeys(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeys(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeys(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeys(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getKeySizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeySpace() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getKeyTransformationHandler() - Method in class org.infinispan.query.backend.QueryInterceptor
 
getKeyType() - Method in interface org.infinispan.distribution.group.Grouper
 
GetKeyValueCommand - Class in org.infinispan.commands.read
Implements functionality defined by Map.get(Object) and Map.containsKey(Object) operations
GetKeyValueCommand(Object, CacheNotifier, Set<Flag>) - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
GetKeyValueCommand() - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
getL1InvalidationCleanupTaskFrequency() - Method in class org.infinispan.config.Configuration
Deprecated.  
getL1InvalidationCleanupTaskFrequency() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
getL1InvalidationThreshold() - Method in class org.infinispan.config.Configuration
Deprecated.  
getL1Lifespan() - Method in class org.infinispan.config.Configuration
Deprecated.  
getLastElement() - Method in class org.infinispan.tree.Fqn
 
getLastElementAsString() - Method in class org.infinispan.tree.Fqn
If this is the root, returns Fqn.SEPARATOR.
getLastModified() - Method in class org.infinispan.lucene.FileMetadata
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getLastViewId() - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
 
getLeavers(String) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
getLeavers(String) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
getLeavers() - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
 
getLength() - Method in class org.infinispan.io.ByteBuffer
 
getLength() - Method in class org.infinispan.io.GridFile.Metadata
 
getLength() - Static method in class org.infinispan.Version
 
getLifespan() - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
getLifespan() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
getLifespan() - Method in interface org.infinispan.container.entries.CacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLifespan() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getLifespan() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getLifespanMillis() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getLifespanMillis() - Method in class org.infinispan.commands.write.PutMapCommand
 
getLifespanMillis() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getList() - Method in class org.infinispan.loaders.modifications.ModificationsList
 
getListener() - Method in class org.infinispan.cacheviews.CacheViewInfo
 
getListenerCollectionForAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getListeners() - Method in class org.infinispan.AbstractDelegatingCache
 
getListeners() - Method in class org.infinispan.CacheImpl
 
getListeners() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getListeners() - Method in class org.infinispan.manager.DefaultCacheManager
 
getListeners() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getListeners() - Method in interface org.infinispan.notifications.Listenable
 
getLoadAllKeysBinarySql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadAllKeysSql() - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
getLoadAllKeysStringSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadersBuilder() - Method in class org.infinispan.configuration.cache.AbstractLoadersConfigurationChildBuilder
 
getLoadNonExpiredAllRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLoadSomeRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getLocalAddress() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getLocalAddress() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getLocalComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalComponent(Class<T>) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocality(Object) - Method in interface org.infinispan.distribution.DistributionManager
Returns the data locality characteristics of a given key.
getLocality(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getLocallyInterruptedTransactions() - Static method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
Deprecated. 
getLocalName() - Method in enum org.infinispan.configuration.parsing.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.configuration.parsing.Element
Get the local name of this element.
getLocalPreparedXids() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getLocalTransaction(Transaction) - Method in class org.infinispan.transaction.TransactionTable
 
getLocalTransaction() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getLocalTransaction(Xid) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getLocalTransactions() - Method in class org.infinispan.transaction.TransactionTable
 
getLocalTx(Transaction) - Method in class org.infinispan.transaction.TransactionTable
 
getLocalTxCount() - Method in class org.infinispan.transaction.TransactionTable
 
getLocalTxCount() - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getLocalTxThatFailedToComplete() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getLocation() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getLocation() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getLocation() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
getLockAcquisitionTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.  
getLockAcquisitionTimeout() - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
getLockAcquisitionTimeout(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getLockAcquistionTimeout() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getLockAcquistionTimeout() - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
getLockConcurrencyLevel() - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
Returns number of threads expected to use this class concurrently.
getLockedKeys() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getLockedKeys() - Method in interface org.infinispan.context.InvocationContext
Returns the set of keys that are locked for writing.
getLockedKeys() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
getLockedKeys() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getLockedKeysForRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
getLockFromKey(Object) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
For BucketBasedCacheStores the lock should be acquired at bucket level.
getLockFromKey(Object) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getLockFromKey(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
getLockId(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
getLockId(Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
getLockId(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
Returns the 'id' of the lock that will be used to guard access to a given key in the cache.
getLockId(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Returns the 'id' of the lock that will be used to guard access to a given key in the cache.
getLockId(Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getLockingMode() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getLockIntention() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Returns the key this transaction intends to lock.
getLockManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getLockManager() - Method in interface org.infinispan.AdvancedCache
Returns the component that deals with all aspects of acquiring and releasing locks for cache entries.
getLockManager() - Method in class org.infinispan.CacheImpl
 
getLockOwner() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLockOwner() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getLockOwner() - Method in interface org.infinispan.context.InvocationContext
Returns the in behalf of which locks will be aquired.
getLockOwner() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
getLockOwner() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
getLocksHeldAtOrigin() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
getLog() - Method in interface org.infinispan.client.hotrod.impl.protocol.Codec
Logger for Hot Rod client codec
getLog() - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
getLog() - Method in class org.infinispan.client.hotrod.impl.protocol.Codec11
 
getLog(Class<?>) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
getLog() - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
getLog() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getLog() - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash
 
getLog() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getLog() - Method in class org.infinispan.factories.ComponentRegistry
 
getLog() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getLog() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
getLog() - Method in class org.infinispan.interceptors.BatchingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getLog() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getLog() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
getLog() - Method in class org.infinispan.interceptors.CallInterceptor
 
getLog() - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
getLog() - Method in class org.infinispan.interceptors.DistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
getLog() - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
getLog() - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
getLog() - Method in class org.infinispan.interceptors.NotificationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
getLog() - Method in class org.infinispan.interceptors.TxInterceptor
 
getLog() - Method in class org.infinispan.interceptors.VersionedDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.VersionedReplicationInterceptor
 
getLog() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
getLog() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getLog() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getLog() - Method in class org.infinispan.query.backend.LocalQueryInterceptor
 
getLog() - Method in class org.infinispan.query.backend.QueryInterceptor
 
getLog() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getLog() - Method in interface org.infinispan.remoting.transport.Transport
 
getLog(Class<?>) - Static method in class org.infinispan.util.logging.BasicLogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.util.logging.BasicLogFactory
 
getLog(Class<?>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLogFlushTimeout() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getLongProperty(String, long) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getLongProperty(String, long, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getLongProperty(String, long) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getLongProperty(String, long) - Method in class org.infinispan.util.TypedProperties
 
getLongProperty(String, long, boolean) - Method in class org.infinispan.util.TypedProperties
 
getLookedUpEntries() - Method in interface org.infinispan.context.EntryLookup
Retrieves a map of entries looked up within the current scope.
getLookedUpEntries() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
getLookedUpEntries() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getLookedUpEntries() - Method in class org.infinispan.transaction.LocalTransaction
 
getLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getMachineId() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMachineId() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getMachineId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getMachineId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getMap() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMarshaller() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getMarshaller() - Method in class org.infinispan.loaders.AbstractCacheStore
 
getMarshaller() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getMarshallerClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMarshallerClass() - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
getMarshallVersion() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMarshallVersionString() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMaxConnections() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getMaxDoublingSize() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxDoublingSize() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxEntries() - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
getMaxIdle() - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
getMaxIdle() - Method in interface org.infinispan.container.entries.CacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getMaxIdle() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getMaxIdleTimeMillis() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getMaxIdleTimeMillis() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMaxIdleTimeMillis() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getMaxNonProgressingLogWrites() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getMaxNumberOfKeys() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getMaxTxRetries() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
getMBeanInfo() - Method in class org.infinispan.jmx.ResourceDMBean
 
getMBeanServer(Properties) - Method in class org.infinispan.jmx.JBossMBeanServerLookup
 
getMBeanServer(Properties) - Method in interface org.infinispan.jmx.MBeanServerLookup
Retrieves an MBeanServer instance.
getMBeanServer(Properties) - Method in class org.infinispan.jmx.PlatformMBeanServerLookup
 
getMBeanServerLookup() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMBeanServerLookup() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
getMBeanServerLookupInstance() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMBeanServerLookupInstance() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
getMBeanServerProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getMembers() - Method in class org.infinispan.cacheviews.CacheView
 
getMembers() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getMembers() - Method in class org.infinispan.manager.DefaultCacheManager
getMembers() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getMembers() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getMembers() - Method in interface org.infinispan.remoting.transport.Transport
Returns a list of members in the current cluster view.
getMembersAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getMembersAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getMembersAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getMembersAtStart() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getMembersJoined(List<Address>, List<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMembersJoined(Set<Address>, Set<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMembersLeft(List<Address>, List<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMembersLeft(Set<Address>, Set<Address>) - Static method in class org.infinispan.remoting.MembershipArithmetic
 
getMetadata() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getMetadataFilename() - Method in interface org.infinispan.factories.components.ModuleMetadataFileFinder
 
getMetadataFilename() - Method in class org.infinispan.query.QueryMetadataFileFinder
 
getMethod() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getMethod() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getMethod() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getMethod() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
getMethodName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getMethodName() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
getMethodName() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getMethodParameters() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getMinViewId() - Method in class org.infinispan.transaction.TransactionTable
 
getMisses() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getMisses() - Method in interface org.infinispan.stats.Stats
 
getMisses() - Method in class org.infinispan.stats.StatsImpl
 
getModificationQueueSize() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getModifications() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getModifications() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getModifications() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns all the modifications performed in the scope of the current transaction.
getModifications() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
getModifications() - Method in class org.infinispan.distribution.RemoteTransactionLogDetails
 
getModifications() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the modifications visible within the current transaction.
getModificationsCount() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getModificationTime() - Method in class org.infinispan.io.GridFile.Metadata
 
getModuleCommandFactory() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
getModuleCommandFactory() - Method in class org.infinispan.query.QueryModuleCommandExtensions
 
getModuleCommandInitializer() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
getModuleCommandInitializer() - Method in class org.infinispan.query.QueryModuleCommandExtensions
 
getModuleCommandInitializers() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getModuleCommands() - Method in interface org.infinispan.commands.module.ModuleCommandFactory
Provides a map of command IDs to command types of all the commands handled by the command factory instance.
getModuleCommands() - Method in class org.infinispan.query.CommandFactory
 
getModuleMetadataFiles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
Retrieves an Iterable containing metadata file finders declared by each module.
getModuleProperties() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getMyId() - Method in class org.infinispan.query.clustered.QueryBox
Id of this QueryBox
getName() - Method in class org.infinispan.AbstractDelegatingCache
 
getName() - Method in interface org.infinispan.api.BasicCache
Retrieves the name of the cache
getName() - Method in class org.infinispan.CacheImpl
 
getName() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getName() - Method in class org.infinispan.config.Configuration
Deprecated. Returns the name of the cache associated with this configuration.
getName() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getName() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getName() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
getName() - Method in class org.infinispan.io.GridFile
 
getName() - Method in class org.infinispan.manager.DefaultCacheManager
 
getName() - Method in class org.infinispan.nearcache.cdi.AddressController
 
getName() - Method in class org.infinispan.spring.provider.SpringCache
 
getName() - Method in class org.infinispan.tools.schema.TreeNode
 
getNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedConfigurationBuilders() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getNativeCache() - Method in class org.infinispan.spring.provider.SpringCache
 
getNativeCacheManager() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
Return the org.infinispan.manager.EmbeddedCacheManager that backs this CacheManager.
getNativeCacheManager() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
Return the org.infinispan.client.hotrod.RemoteCacheManager that backs this SpringRemoteCacheManager.
getNewBufferSize(int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Gets the number of bytes to which the internal buffer should be resized.
getNewBufferSize(int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the number of bytes to which the internal buffer should be resized.
getNewCacheViewId() - Method in exception org.infinispan.statetransfer.StateTransferInProgressException
 
getNewConsistentHash() - Method in class org.infinispan.distribution.ch.UnionConsistentHash
 
getNewInstance() - Method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
 
getNewMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getNewMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getNewValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getNewViewId() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getNewViewId() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Retrieves the next interceptor in the chain.
getNext() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getNextPosition() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
getNode(Fqn) - Method in interface org.infinispan.tree.TreeCache
A convenience method to retrieve a node directly from the cache.
getNode(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getNode(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
getNode(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getNode(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNode(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNode(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNode(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getNodeAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNodeAddress() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getNodeName() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getNodeUuid() - Method in interface org.infinispan.query.clustered.ClusteredDoc
 
getNodeUuid() - Method in class org.infinispan.query.clustered.ClusteredFieldDoc
 
getNodeUuid() - Method in class org.infinispan.query.clustered.ClusteredScoreDoc
 
getNodeUUID() - Method in class org.infinispan.query.clustered.QueryResponse
 
getNonCacheComponents(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
getNonClusteredDefault() - Static method in class org.infinispan.config.GlobalConfiguration
Deprecated. Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
getNormalizedHash(Object) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
getNormalizedHash(Object) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
getNormalizedHash(Object) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
getNormalizedHash(Object, Hash) - Static method in class org.infinispan.util.Util
 
getNucleotideDetails(String) - Method in class org.infinispan.ec2demo.NucleotideCache
 
getNumberOfChunks() - Method in class org.infinispan.lucene.FileMetadata
 
getNumberOfEntries() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getNumberOfEntries() - Method in class org.infinispan.nearcache.cdi.AddressCacheManager
 
getNumberOfLocksAvailable() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumberOfLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the number of locks currently held.
getNumberOfLocksHeld() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumberWorkerThreads() - Method in interface org.infinispan.server.core.transport.Transport
 
getNumEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
getNumLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
getNumOwners() - Method in class org.infinispan.config.Configuration
Deprecated.  
getNumOwners() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
getNumRetries() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getNumVirtualNodes() - Method in class org.infinispan.config.Configuration
Deprecated.  
getNumVirtualNodes() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
getObject() - Method in class org.infinispan.spring.provider.ContainerCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
getObject() - Method in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
 
getObject() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
 
getObject() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
 
getObjectName(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName(String, String, String) - Static method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName() - Method in class org.infinispan.jmx.ResourceDMBean
 
getObjectType() - Method in class org.infinispan.spring.provider.ContainerCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
 
getObjectWriter(Object) - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
getOffset() - Method in class org.infinispan.io.ByteBuffer
 
getOldConsistentHash() - Method in class org.infinispan.distribution.ch.UnionConsistentHash
 
getOldMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getOldMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getOldValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
GetOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "get" operation as described by Hot Rod protocol specification.
GetOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetOperation
 
getOperationMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getOrCreateComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component if one exists, and if not, attempts to find a factory capable of constructing the component (factories annotated with the DefaultFactoryFor annotation that is capable of creating the component class).
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getOrCreateLocalTransaction(Transaction, TxInvocationContext) - Method in class org.infinispan.transaction.TransactionTable
Returns the TransactionXaAdapter corresponding to the supplied transaction.
getOrigin() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
getOrigin() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
getOrigin() - Method in interface org.infinispan.commands.remote.CacheRpcCommand
Get the origin of the command
getOrigin() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getOrigin() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
getOrigin() - Method in class org.infinispan.context.impl.ImmutableContext
 
getOrigin() - Method in interface org.infinispan.context.InvocationContext
Get the origin of the command, or null if the command originated locally
getOrigin() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
getOutput(String) - Method in class org.infinispan.io.GridFilesystem
Opens an OutputStream for writing to the file denoted by pathname.
getOutput(String, boolean) - Method in class org.infinispan.io.GridFilesystem
Opens an OutputStream for writing to the file denoted by pathname.
getOutput(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
Opens an OutputStream for writing to the file denoted by pathname.
getOutput(GridFile) - Method in class org.infinispan.io.GridFilesystem
Opens an OutputStream for writing to the given file.
getOverlapWithNotDeadlockAwareLockOwners() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getOwner(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the write lock owner, if any, for the specified cache entry.
getOwner(Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getOwner() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
getOwners(Collection<Object>) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getOwners() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
getOwners() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
Returns the set of nodes where this transaction information is maintained.
getParameterClasses() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getParameterName(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getParameterPosition() - Method in class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
getParameters() - Method in class org.infinispan.cdi.interceptor.context.metadata.AggregatedParameterMetaData
 
getParameters() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getParameters() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
getParameters() - Method in class org.infinispan.commands.control.LockControlCommand
 
getParameters() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getParameters() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getParameters() - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
getParameters() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getParameters() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
getParameters() - Method in class org.infinispan.commands.read.MapReduceCommand
 
getParameters() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getParameters() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getParameters() - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
getParameters() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
getParameters() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
getParameters() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
getParameters() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getParameters() - Method in class org.infinispan.commands.RemoveCacheCommand
 
getParameters() - Method in interface org.infinispan.commands.ReplicableCommand
Used by marshallers to stream this command across a network
getParameters() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getParameters() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getParameters() - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
getParameters() - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
getParameters() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getParameters() - Method in class org.infinispan.commands.write.ClearCommand
 
getParameters() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getParameters() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
getParameters() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getParameters() - Method in class org.infinispan.commands.write.PutMapCommand
 
getParameters() - Method in class org.infinispan.commands.write.RemoveCommand
 
getParameters() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getParameters() - Method in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
getParameters() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getParameters() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
getParent() - Method in class org.infinispan.io.GridFile
 
getParent() - Method in class org.infinispan.tools.schema.TreeNode
 
getParent() - Method in class org.infinispan.tree.Fqn
Returns the parent of this Fqn.
getParent() - Method in interface org.infinispan.tree.Node
Returns the parent node.
getParent(Flag...) - Method in interface org.infinispan.tree.Node
 
getParent() - Method in class org.infinispan.tree.NodeImpl
 
getParent(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
getParentFile() - Method in class org.infinispan.io.GridFile
 
getPassivationCount() - Method in interface org.infinispan.eviction.PassivationManager
 
getPassivationCount() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
getPassivations() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
getPassword() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getPassword() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getPassword() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getPassword() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getPath() - Method in class org.infinispan.io.GridFile
Returns path of this file.
getPendingChanges() - Method in class org.infinispan.cacheviews.CacheViewInfo
 
getPendingPreparesMap() - Method in class org.infinispan.distribution.RemoteTransactionLogDetails
 
getPendingView() - Method in class org.infinispan.cacheviews.CacheViewInfo
 
getPendingView(String) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
getPendingView(String) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
getPendingViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getPhysicalAddresses() - Method in class org.infinispan.manager.DefaultCacheManager
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getPhysicalAddresses() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's physical network addresses.
getPingOnStartup() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getPooledDataSource() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
getPoolProperties() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getPort() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getPort() - Method in interface org.infinispan.server.core.transport.Transport
 
getPosition() - Method in class org.infinispan.cdi.interceptor.context.metadata.ParameterMetaData
 
getPosition() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getPositionAsString() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getPositionIndex(int) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
getPositionsIterator(int) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
Creates an iterator over the positions "map" starting at the index specified by the normalizedHash.
getPreparedTransaction(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Local call returning the remote transaction identified by the supplied xid or null.
getPreparedTransaction(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getPreparedTransactionsFromCluster() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Returns the list of transactions in prepared state from both local and remote cluster nodes.
getPreparedTransactionsFromCluster() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getPrepares() - Method in class org.infinispan.interceptors.TxInterceptor
 
getPrepareStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getPrimaryLocation(Object) - Method in interface org.infinispan.distribution.DistributionManager
Returns the first Address containing the key.
getPrimaryLocation(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getPriority() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
getProgrammaticMapping() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProperties() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getProperties() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves a clone of the properties currently in use.
getProperties() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getProperties() - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated. 
getProperties() - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
getProperties() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProperty(String, String, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
Get the property associated with the key, optionally applying string property replacement as defined in StringPropertyReplacer.replaceProperties(java.lang.String) to the result.
getProperty(String) - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProperty(String, String) - Static method in class org.infinispan.util.LegacyKeySupportSystemProperties
 
getProperty(String, String, String) - Static method in class org.infinispan.util.LegacyKeySupportSystemProperties
 
getProperty(String) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getProperty(String, String) - Method in class org.infinispan.util.LegacyKeySupportTypedProperties
 
getProperty(String, String) - Static method in class org.infinispan.util.SysPropertyActions
 
getProperty(String) - Static method in class org.infinispan.util.SysPropertyActions
 
getProperty(String, String, boolean) - Method in class org.infinispan.util.TypedProperties
Get the property associated with the key, optionally applying string property replacement as defined in StringPropertyReplacer.replaceProperties(java.lang.String) to the result.
getPropertyFromBeanConvention(Method) - Static method in class org.infinispan.tools.BeanConventions
 
getPropertyFromBeanConvention(Field) - Static method in class org.infinispan.tools.BeanConventions
 
getProtein_Data() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
getProteinDetails(String) - Method in class org.infinispan.ec2demo.ProteinCache
 
getProtocolVersion() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getProtocolVersion() - Static method in class org.infinispan.client.hotrod.Version
 
getProvidedServices() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProxyHost() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getProxyPort() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getPurgerThreads() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getPurgerThreads() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getPurgerThreads() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
getPushStateTimeout() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
getQuery(Query, Class<?>...) - Method in interface org.infinispan.query.SearchManager
This is a simple method that will just return a CacheQuery, filtered according to a set of classes passed in.
getQueryBox() - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
getRackId() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getRackId() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getRackId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getRackId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getRaw() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Gets the internal buffer array.
getRaw() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
 
getRaw() - Method in class org.infinispan.io.MarshalledValueByteStream
 
getRaw() - Method in class org.infinispan.marshall.MarshalledValue
 
getRawBuffer() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Gets the internal buffer array.
getRawType() - Method in class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
getRawType() - Method in class org.infinispan.cdi.interceptor.context.metadata.ParameterMetaData
 
getReadableChannel(String) - Method in class org.infinispan.io.GridFilesystem
Opens a ReadableGridFileChannel for reading from the file denoted by the given file path.
getReadConsistencyLevel() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getReadOnlyAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Retrieves an atomic map from a given cache, stored under a given key, for reading only.
getReadWriteRatio() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getRealAddress() - Method in class org.infinispan.distribution.ch.VirtualAddress
 
getReceiveBufferSize() - Method in interface org.infinispan.server.core.transport.Transport
 
getRecoveryInfoCacheName() - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
getRecoveryManager() - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getReferencedObject(int) - Method in class org.infinispan.marshall.UnmarshalledReferences
Retrieves an object referenced by an id
getReflectionManager() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Returns an immutable set containing all the components that exists in the repository at this moment.
getRehashRpcTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.  
getRehashRpcTimeout() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
getRehashWait() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
getRehashWaitTime() - Method in class org.infinispan.config.Configuration
Deprecated.  
getRemoteCache(InjectionPoint) - Method in class org.infinispan.cdi.RemoteCacheProducer
Produces the remote cache.
getRemoteCacheManager() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the RemoteCacheManager that created this cache.
getRemoteCacheName() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
getRemoteCallTimeout() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
getRemoteLockIntention() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
getRemoteLocksAcquired() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getRemoteLocksAcquired() - Method in class org.infinispan.transaction.LocalTransaction
 
getRemoteSocketAddress() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
getRemoteSocketAddress() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
Returns the address of the endpoint this transport is connected to, or null if it is unconnected.
getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
Returns the RemoteTransaction associated with the supplied transaction id.
getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getRemoteTransactions() - Method in class org.infinispan.transaction.TransactionTable
 
getRemoteTransactionXid(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
Iterates over the remote transactions and returns the XID of the one that has an internal id equal with the supplied internal Id.
getRemoteTxCount() - Method in class org.infinispan.transaction.TransactionTable
 
getRemoveHits() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getRemoveHits() - Method in interface org.infinispan.stats.Stats
 
getRemoveHits() - Method in class org.infinispan.stats.StatsImpl
 
getRemoveMisses() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getRemoveMisses() - Method in interface org.infinispan.stats.Stats
 
getRemoveMisses() - Method in class org.infinispan.stats.StatsImpl
 
getReplicationCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getReplicationFailures() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getReplicationQueueScheduledExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getReplicationQueueScheduledExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getReplQueueClass() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
getReplQueueClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
getReplQueueInterval() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
getReplQueueInterval() - Method in class org.infinispan.config.Configuration
Deprecated.  
getReplQueueMaxElements() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
getReplQueueMaxElements() - Method in class org.infinispan.config.Configuration
Deprecated.  
getReplTimeout() - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.  
getRequestBalancingStrategy() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getRequestTimeout() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
getResourceContent(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
getResourceLength(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DefaultResponseGenerator
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
getResponse(CacheRpcCommand, Object) - Method in interface org.infinispan.remoting.responses.ResponseGenerator
 
getResponseGenerator() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StateTransferManager.class);
getResponseValue() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
getResult() - Method in class org.infinispan.nearcache.cdi.AddressController
 
getResultSize() - Method in interface org.infinispan.query.CacheQuery
Gets the integer number of results.
getResultSize() - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
getResultSize(HSQuery, Cache<?, ?>) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
getResultSize() - Method in class org.infinispan.query.clustered.QueryResponse
 
getResultSize() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
getRetrievals() - Method in interface org.infinispan.stats.Stats
 
getRetrievals() - Method in class org.infinispan.stats.StatsImpl
 
getRetryWaitTimeIncreaseFactor() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getRollbacks() - Method in class org.infinispan.interceptors.TxInterceptor
 
getRollbackViewId() - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
Called on the coordinator before a rollback to assign a unique view id to the rollback.
getRoot() - Method in class org.infinispan.loaders.file.FileCacheStore
 
getRoot() - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
getRoot() - Method in interface org.infinispan.tree.TreeCache
Returns the root node of this cache.
getRoot(Flag...) - Method in interface org.infinispan.tree.TreeCache
 
getRoot() - Method in class org.infinispan.tree.TreeCacheImpl
 
getRoot(Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
getRootDoc() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getRootElementName() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Name of the root element in the schema
getRootElementName() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
getRowCount() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getRowCount() - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getRpcManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getRpcManager() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of communication with other caches in the cluster.
getRpcManager() - Method in class org.infinispan.CacheImpl
 
getRunningCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getScheduledExecutor(Properties) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties) - Method in interface org.infinispan.executors.ScheduledExecutorFactory
 
getSchemaFile() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Returns name of the schema file.
getSchemaFile() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
getSearchFactory() - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
getSearchFactory() - Method in interface org.infinispan.query.SearchManager
Experimental.
getSearchManager(Cache<?, ?>) - Static method in class org.infinispan.query.Search
 
getSelectExpiredRowsSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getSelectRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getSendBufferSize() - Method in interface org.infinispan.server.core.transport.Transport
 
getSequenceLength() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getServer(byte[]) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
getServer(byte[]) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
getServerAddress() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
getServerList() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getServers() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
getServers() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getSetStateException() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
getSharedLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getShutdownHookBehavior() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getShutdownTimeout() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getSingleKey() - Method in class org.infinispan.commands.control.LockControlCommand
 
getSingletonStoreConfig() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getSingletonStoreConfig() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
getSingletonStoreConfig() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
getSiteId() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getSiteId() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getSiteId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getSiteId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getSize() - Method in class org.infinispan.lucene.FileMetadata
 
getSoTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getSoTimeout() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getSoTimeout() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getSpinDuration() - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
getStartMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getStateFlags() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getStateFlags() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getStateFlags() - Method in interface org.infinispan.container.entries.StateChangingEntry
 
getStateProvidersOnJoin(Address, int) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
getStateProvidersOnJoin(Address, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated. No longer supported. This method doesn't make sense with virtual nodes enabled.
getStateProvidersOnLeave(Address, int) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
getStateProvidersOnLeave(Address, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated. No longer supported. This method doesn't make sense with virtual nodes enabled.
getStateRetrievalChunkSize() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateRetrievalInitialRetryWaitTime() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateRetrievalLogFlushTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateRetrievalMaxNonProgressingLogWrites() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateRetrievalNumRetries() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateRetrievalRetryWaitTimeIncreaseFactor() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateRetrievalTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.  
getStateTransferManager() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StateTransferManager.class);
getStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
Returns whether an interceptor's statistics are being captured.
getStatisticsEnabled() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Returns whether an interceptor's statistics are being captured.
getStats() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getStats() - Method in interface org.infinispan.AdvancedCache
Returns a Stats object that allows several statistics associated with this cache at runtime.
getStats() - Method in class org.infinispan.CacheImpl
 
getStatsMap() - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatsMap() - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getStatus() - Method in class org.infinispan.AbstractDelegatingCache
 
getStatus() - Method in interface org.infinispan.Cache
 
getStatus() - Method in class org.infinispan.CacheImpl
 
getStatus() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the state of the registry
getStatus() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStatus() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Get the status of the transaction associated with the calling thread.
getStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
getStatus() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Following values might be returned: - Status.STATUS_PREPARED if the tx is prepared - Status.STATUS_COMMITTED if the tx is committed - Status.STATUS_ROLLEDBACK if the tx is rollback - null otherwise
getStatus() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
The value represent transaction's state as described by the Status field.
getStopMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getStoredEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getStoredEntry() - Method in class org.infinispan.loaders.modifications.Store
 
getStoredObject(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
getStores() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getStores() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
getStores() - Method in interface org.infinispan.stats.Stats
 
getStores() - Method in class org.infinispan.stats.StatsImpl
 
getStrategy() - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
getStream() - Method in class org.infinispan.io.ByteBuffer
 
getStreamBufferSize() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getStreet() - Method in class org.infinispan.nearcache.cdi.AddressController
 
getStrictPeerToPeer() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getStringBasedCacheStore() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
getStringBuilder() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getStringMapping(Object) - Method in class org.infinispan.loaders.keymappers.DefaultTwoWayKey2StringMapper
 
getStringMapping(Object) - Method in interface org.infinispan.loaders.keymappers.Key2StringMapper
Must return an unique String for the supplied key.
getStringMapping(Object) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
 
getStringRepresentation(Object[]) - Method in class org.infinispan.tree.Fqn
 
getSubElement(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns a named sub-element of the current element passed in.
getSubFqn(int, int) - Method in class org.infinispan.tree.Fqn
Obtains a sub-Fqn from the given Fqn.
getSubgroupsMerged() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getSubgroupsMerged() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.MergeEvent
 
getSubType() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getSuccessRatio() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuccessRatioFloatingPoint() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuspect() - Method in exception org.infinispan.remoting.transport.jgroups.SuspectException
 
getSyncReplTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.  
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
getTableManipulation() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
getTableName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTableNamePrefix() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTagContents(Element, String, String, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns the contents of a specific node of given element name, provided a certain attribute exists and is set to value.
getTarget() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getterMethod(Class<?>, Class<?>) - Static method in class org.infinispan.util.BeanUtils
Returns a Method object corresponding to a getter that retrieves an instance of componentClass from target.
getterName(Class<?>) - Static method in class org.infinispan.util.BeanUtils
Returns a getter for a given class
getThreadPolicy() - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
getThreadPoolSize() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getTimeout() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
getTimeout() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
getTimeout() - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
getTimeout() - Method in class org.infinispan.statetransfer.DummyInvalidationStateTransferManagerImpl
Deprecated.  
getTimeout() - Method in class org.infinispan.statetransfer.ReplicatedStateTransferManagerImpl
 
getTimeSinceReset() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
 
getTimeSinceStart() - Method in class org.infinispan.stats.StatsImpl
 
getTimestampColumnName() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTimestampColumnType() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getTitle() - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
getTitle() - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
getTopDocs() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getTopDocs() - Method in class org.infinispan.query.clustered.QueryResponse
 
getTotalBytesRead() - Method in interface org.infinispan.server.core.transport.Transport
 
getTotalBytesWritten() - Method in interface org.infinispan.server.core.transport.Transport
 
getTotalLockCount() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
getTotalLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
Returns the total number of locks held by this class.
getTotalNumberOfDetectedDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getTotalNumberOfEntries() - Method in interface org.infinispan.stats.Stats
 
getTotalNumberOfEntries() - Method in class org.infinispan.stats.StatsImpl
 
getTotalReadLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getTotalWriteLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getTpcNoDelay() - Method in interface org.infinispan.server.core.transport.Transport
 
getTransaction() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the tx associated with the current thread.
getTransaction() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
getTransaction() - Method in class org.infinispan.transaction.LocalTransaction
 
getTransaction() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Get the transaction associated with the calling thread.
getTransactionIdentifier() - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Returns a JTA transaction.
getTransactionLockingMode() - Method in class org.infinispan.config.Configuration
Deprecated. Returns the locking mode for this cache.
getTransactionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getTransactionManager() - Method in interface org.infinispan.AdvancedCache
Returns the transaction manager configured for this cache.
getTransactionManager() - Method in class org.infinispan.CacheImpl
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
Get the systemwide used TransactionManager
getTransactionManager() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.JBossTransactionManagerLookup
 
getTransactionManager() - Method in interface org.infinispan.transaction.lookup.TransactionManagerLookup
Returns a new TransactionManager.
getTransactionManagerLookup() - Method in class org.infinispan.config.Configuration
Deprecated.  
getTransactionManagerLookupClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
getTransactionManagerLookupClass() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getTransactionMode() - Method in class org.infinispan.config.Configuration
Deprecated. Returns cache's transaction mode.
getTransactionMode() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getTransactionRecoveryCacheName() - Method in class org.infinispan.config.Configuration
Deprecated. Returns the name of the cache used in order to keep recovery information.
getTransactionSynchronizationRegistry() - Method in interface org.infinispan.transaction.lookup.TransactionSynchronizationRegistryLookup
Returns a new TransactionSynchronizationRegistry.
getTransactionSynchronizationRegistryLookup() - Method in class org.infinispan.config.Configuration
Deprecated.  
getTransactionSynchronizationRegistryLookup() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getTransactionTimeout() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.FaultTolerantPingOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
getTransport() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransport(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransport() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransport(byte[]) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getTransport() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getTransport() - Method in class org.infinispan.manager.DefaultCacheManager
 
getTransport() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getTransport() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTransport() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTransportClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getTransportClass() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
getTransportCount() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransportCount() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
getTransportFactory() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
getTransportNodeName() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getTransportProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
getType() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
getType() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
getType() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
getType() - Method in class org.infinispan.loaders.modifications.Clear
 
getType() - Method in interface org.infinispan.loaders.modifications.Modification
 
getType() - Method in class org.infinispan.loaders.modifications.ModificationsList
 
getType() - Method in class org.infinispan.loaders.modifications.PurgeExpired
 
getType() - Method in class org.infinispan.loaders.modifications.Remove
 
getType() - Method in class org.infinispan.loaders.modifications.Store
 
getType() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getType() - Method in class org.infinispan.tools.schema.TreeNode
 
getTypeClasses() - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cacheviews.CacheView.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.hash.MurmurHash2.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.hash.MurmurHash2Compat.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.context.Flag.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.UnionConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.RemoteTransactionLogDetails.Externalizer
 
getTypeClasses() - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
getTypeClasses() - Method in interface org.infinispan.marshall.AdvancedExternalizer
Returns a collection of Class instances representing the types that this AdvancedExternalizer can marshall.
getTypeClasses() - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.LinkedListExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MapExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.SetExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.SingletonListExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
getTypeClasses() - Method in class org.infinispan.statetransfer.LockInfo.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
 
getTypeClasses() - Method in class org.infinispan.tree.Fqn.Externalizer
 
getTypeClasses() - Method in class org.infinispan.tree.NodeKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
getTypedProperties() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getUncommitted(Object) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
getUncommittedChages() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getUpdatedEntryVersions() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getUpdatedEntryVersions() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getUpdatedVersions() - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
getUpdateRowSql() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
getUriString() - Method in enum org.infinispan.configuration.parsing.Namespace
Get the URI of this namespace.
getUse1PcForAutoCommitTransactions() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
getUsername() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getUserName() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
getUserName() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
getUserTransaction() - Static method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getUserTransaction() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getValue() - Method in class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
getValue() - Method in class org.infinispan.client.hotrod.impl.BinaryVersionedValue
 
getValue(Properties, String, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.PropsKeyedObjectPoolFactory
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getValue() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
getValue() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getValue() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the value of this entry
getValue() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getValue() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getValue() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig.FsyncModeEditor
 
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryActivatedEvent
Retrieves the value of the entry being activated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvictedEvent
Deprecated. Retrieves the value of the entry being evicted.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryInvalidatedEvent
Retrieves the value of the entry being activated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryLoadedEvent
Retrieves the value of the entry being loaded.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Retrieves the value of the entry being modified.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryPassivatedEvent
Retrieves the value of the entry being passivated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Retrieves the value of the entry being deleted.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryVisitedEvent
Retrieves the value of the entry being visited.
getValue() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getValue(int, Address, UUID) - Method in class org.infinispan.query.clustered.ClusteredQueryInvoker
Retrieves the value (using doc index) in a remote query instance
getValue(UUID, int) - Method in class org.infinispan.query.clustered.QueryBox
Get the "docIndex" value on the correct DocumentExtractor
getValue() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
getValue(Object, String) - Static method in class org.infinispan.util.ReflectionUtil
Retrieves the value of a field of an object instance via reflection
getValue() - Method in class org.infinispan.util.SimpleImmutableEntry
 
getValueAt(int, int) - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
getValueAt(int, int) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
getValueParameter() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
getValueParameter() - Method in class org.infinispan.cdi.interceptor.context.metadata.AggregatedParameterMetaData
 
getValueParameter() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
getValues(MeasurementReport, Set<MeasurementScheduleRequest>) - Method in class org.infinispan.rhq.CacheComponent
Gather measurement data
getValues(MeasurementReport, Set<MeasurementScheduleRequest>) - Method in class org.infinispan.rhq.CacheManagerComponent
Gather measurement data
getValueSizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getVersion() - Method in class org.infinispan.AbstractDelegatingCache
 
getVersion() - Method in interface org.infinispan.api.BasicCache
Retrieves the version of Infinispan
getVersion() - Method in class org.infinispan.CacheImpl
 
getVersion() - Static method in class org.infinispan.cdi.util.Version
Returns the version of the CDI extension.
getVersion() - Method in class org.infinispan.client.hotrod.impl.BinaryVersionedValue
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getVersion() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
getVersion() - Method in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
getVersion() - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
getVersion() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getVersion() - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
getVersion() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getVersion() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getVersion() - Method in interface org.infinispan.container.entries.versioned.Versioned
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry
 
getVersion() - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue
 
getVersion() - Method in class org.infinispan.manager.DefaultCacheManager
 
getVersion2ConsistentHash() - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
getVersioned(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersioned(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the VersionedValue associated to the supplied key param, or null if it doesn't exist.
getVersioningScheme() - Method in class org.infinispan.config.Configuration
Deprecated. 
getVersioningScheme() - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
getVersionShort() - Static method in class org.infinispan.Version
 
getVersionShort(String) - Static method in class org.infinispan.Version
 
getVersionsSeen() - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
getViewId() - Method in class org.infinispan.cacheviews.CacheView
 
getViewId() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getViewId() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getViewId() - Method in interface org.infinispan.remoting.transport.Transport
 
getViewId() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getViewId() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getVirusDetails(String) - Method in class org.infinispan.ec2demo.InfluenzaVirusCache
 
getVirusName() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
getWakeUpInterval() - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated. Use Configuration.getExpirationWakeUpInterval()
getWakeUpInterval() - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
getWarningMessage(String, Location) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getWithVersion(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
Returns null if the given key does not exist.
GetWithVersionOperation - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to getWithVersion operation as described by Hot Rod protocol specification.
GetWithVersionOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetWithVersionOperation
 
getWritableChannel(String) - Method in class org.infinispan.io.GridFilesystem
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
getWritableChannel(String, boolean) - Method in class org.infinispan.io.GridFilesystem
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
getWritableChannel(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
getWriteConsistencyLevel() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
getXAResource() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getXAResource() - Method in interface org.infinispan.AdvancedCache
Returns the XAResource associated with this cache which can be used to do transactional recovery.
getXAResource() - Method in class org.infinispan.CacheImpl
 
getXid() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getXid() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
 
getXid() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
getXid() - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
 
getXid() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
getXid() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
getXid() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
Transaction's id.
getYearFound() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
GLOBAL_MARSHALLER - Static variable in class org.infinispan.factories.KnownComponentNames
 
GLOBAL_TRANSACTION - Static variable in interface org.infinispan.marshall.Ids
 
globalComponentRegistry - Variable in class org.infinispan.factories.AbstractComponentFactory
 
GlobalComponentRegistry - Class in org.infinispan.factories
A global component registry where shared components are stored.
GlobalComponentRegistry(GlobalConfiguration, EmbeddedCacheManager, Set<String>) - Constructor for class org.infinispan.factories.GlobalComponentRegistry
Creates an instance of the component registry.
GlobalConfiguration - Class in org.infinispan.config
Deprecated. This class is deprecated. Use GlobalConfiguration instead.
GlobalConfiguration() - Constructor for class org.infinispan.config.GlobalConfiguration
Deprecated. Create a new GlobalConfiguration, using the Thread Context ClassLoader to load any classes or resources required by this configuration.
GlobalConfiguration(ClassLoader) - Constructor for class org.infinispan.config.GlobalConfiguration
Deprecated. Create a new GlobalConfiguration, specifying the classloader to use.
GlobalConfiguration - Class in org.infinispan.configuration.global
Configuration component that exposes the global configuration.
globalConfiguration - Variable in class org.infinispan.factories.AbstractComponentFactory
 
globalConfiguration - Variable in class org.infinispan.manager.DefaultCacheManager
 
globalConfiguration - Variable in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory.ConfigurationContainer
 
GlobalConfiguration.AdvancedExternalizersType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.AdvancedExternalizersType() - Constructor for class org.infinispan.config.GlobalConfiguration.AdvancedExternalizersType
Deprecated.  
GlobalConfiguration.ExecutorFactoryType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.ExecutorFactoryType(String) - Constructor for class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
GlobalConfiguration.ExecutorFactoryType() - Constructor for class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
GlobalConfiguration.FactoryClassWithPropertiesType - Class in org.infinispan.config
Deprecated.  
GlobalConfiguration.FactoryClassWithPropertiesType() - Constructor for class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
GlobalConfiguration.GlobalJmxStatisticsType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.GlobalJmxStatisticsType() - Constructor for class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
GlobalConfiguration.ScheduledExecutorFactoryType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.ScheduledExecutorFactoryType(String) - Constructor for class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
GlobalConfiguration.ScheduledExecutorFactoryType() - Constructor for class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
GlobalConfiguration.SerializationType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.SerializationType() - Constructor for class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
GlobalConfiguration.ShutdownHookBehavior - Enum in org.infinispan.config
Deprecated. 
GlobalConfiguration.ShutdownType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.ShutdownType() - Constructor for class org.infinispan.config.GlobalConfiguration.ShutdownType
Deprecated.  
GlobalConfiguration.TransportType - Class in org.infinispan.config
Deprecated. 
GlobalConfiguration.TransportType() - Constructor for class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
GlobalConfiguration.TransportType(String) - Constructor for class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
GlobalConfigurationBuilder - Class in org.infinispan.configuration.global
 
GlobalConfigurationBuilder() - Constructor for class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
GlobalConfigurationChildBuilder - Interface in org.infinispan.configuration.global
 
globalConfigurationOverrides - Variable in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
This method allows configuration of the global, or cache manager level, jmx statistics.
globalJmxStatistics() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
GlobalJmxStatisticsConfiguration - Class in org.infinispan.configuration.global
 
GlobalJmxStatisticsConfigurationBuilder - Class in org.infinispan.configuration.global
Configures whether global statistics are gathered and reported via JMX for all caches under this cache manager.
GlobalMarshaller - Class in org.infinispan.marshall
A globally-scoped marshaller.
GlobalMarshaller(VersionAwareMarshaller) - Constructor for class org.infinispan.marshall.GlobalMarshaller
 
GlobalTransaction - Class in org.infinispan.transaction.xa
Uniquely identifies a transaction that spans all JVMs in a cluster.
GlobalTransaction() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
empty ctor used by externalization.
GlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
 
GlobalTransaction.AbstractGlobalTxExternalizer<T extends GlobalTransaction> - Class in org.infinispan.transaction.xa
 
GlobalTransaction.AbstractGlobalTxExternalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
 
GlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
 
GlobalTransaction.Externalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
globalTx - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
GridFile - Class in org.infinispan.io
Subclass of File to iterate through directories and files in a grid
GridFile.Metadata - Class in org.infinispan.io
 
GridFile.Metadata() - Constructor for class org.infinispan.io.GridFile.Metadata
 
GridFile.Metadata(int, long, int, byte) - Constructor for class org.infinispan.io.GridFile.Metadata
 
GridFilesystem - Class in org.infinispan.io
Entry point for GridFile and GridInputStream / GridOutputStream
GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>, int) - Constructor for class org.infinispan.io.GridFilesystem
Creates an instance.
GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>) - Constructor for class org.infinispan.io.GridFilesystem
 
GridInputStream - Class in org.infinispan.io
 
GridOutputStream - Class in org.infinispan.io
 
GridStore - Class in org.infinispan.demos.gridfs
 
GridStore(File) - Constructor for class org.infinispan.demos.gridfs.GridStore
 
Group - Annotation Type in org.infinispan.distribution.group
Identifies the key for a group.
Grouper<T> - Interface in org.infinispan.distribution.group
User applications may implement this interface in order to customize the compution of groups in cases when the modifying the key is not possible, or when the value determined by the Group annotation needs customizing.
GrouperConfiguration - Class in org.infinispan.config
 
GrouperConfiguration() - Constructor for class org.infinispan.config.GrouperConfiguration
 
groupers(List<Grouper<?>>) - Method in interface org.infinispan.config.FluentConfiguration.GroupsConfig
Deprecated. Set the groupers currently in use
groupers(List<Grouper<?>>) - Method in class org.infinispan.config.GroupsConfiguration
 
groupers() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
Get's the current groupers in use
groupKeys(Map<KOut, List<VOut>>, Map<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
groupManager - Variable in class org.infinispan.distribution.ch.AbstractConsistentHash
 
GroupManager - Interface in org.infinispan.distribution.group
Control's key grouping.
GroupManagerImpl - Class in org.infinispan.distribution.group
 
GroupManagerImpl(List<Grouper<?>>) - Constructor for class org.infinispan.distribution.group.GroupManagerImpl
 
groups - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
groups() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
groups() - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated.  
groups() - Method in class org.infinispan.configuration.cache.HashConfiguration
Configuration for various grouper definitions.
groups() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
GroupsConfiguration - Class in org.infinispan.config
 
GroupsConfiguration() - Constructor for class org.infinispan.config.GroupsConfiguration
 
GroupsConfiguration - Class in org.infinispan.configuration.cache
Configuration for various grouper definitions.
GroupsConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration for various grouper definitions.
GroupsConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
GZIP - Static variable in class org.infinispan.util.Base64
Specify that data should be gzip-compressed.

H

handle(Bucket) - Method in interface org.infinispan.loaders.bucket.BucketBasedCacheStore.BucketHandler
Handles a bucket that is passed in.
handle(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
handle(CacheRpcCommand, Address) - Method in interface org.infinispan.remoting.InboundInvocationHandler
Invokes a command on the cache, from a remote source.
handle(CacheRpcCommand, Address) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
handle(Message) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
Message contains a Command.
handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.ListenerRegistration
 
handleClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleCommitCommand(InvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleCommitView(String, int) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
handleCommitView(String, int) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
A default handler for all commands visited.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
The default behaviour of the visitXXX methods, which is to ignore the call and pass the call up to the next interceptor in the chain.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.BatchingInterceptor
Simply check if there is an ongoing tx.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
handleEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleMarshallingException(Throwable, Object) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.GetHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.NotifyHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.PutHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in class org.infinispan.server.websocket.handlers.RemoveHandler
 
handleOp(JSONObject, Cache<Object, Object>, ChannelHandlerContext) - Method in interface org.infinispan.server.websocket.OpHandler
Handle a websocket channel operation.
handlePrepareCommand(InvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePrepareView(String, CacheView, CacheView) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
handlePrepareView(String, CacheView, CacheView) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
handlePutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRecoverViews() - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
handleRecoverViews() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
handleRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRequestJoin(Address, String) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
handleRequestJoin(Address, String) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
Handle a join request.
handleRequestLeave(Address, String) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
handleRequestLeave(Address, String) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
handleRollbackCommand(InvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRollbackView(String, int, int) - Method in interface org.infinispan.cacheviews.CacheViewsManager
 
handleRollbackView(String, int, int) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
handleSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleUnmarshallingException(Throwable, Class<?>) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
handleUnmarshallingException(Throwable) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.ListenerRegistration
 
handleViewChange(ViewChangedEvent) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewListener
 
handleViewChange(ViewChangedEvent) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.ViewIdUpdater
 
handleWriteCommand(WriteCommand, Object) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
handleWriteCommand(WriteCommand, Object) - Method in class org.infinispan.remoting.responses.NoReturnValuesDistributionResponseGenerator
 
hasChanges() - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
 
hasChild(String) - Method in class org.infinispan.tools.schema.TreeNode
 
hasChild(Fqn) - Method in interface org.infinispan.tree.Node
Returns true if the child node denoted by the relative Fqn passed in exists.
hasChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
hasChild(Object) - Method in interface org.infinispan.tree.Node
Returns true if the child node denoted by the Object name passed in exists.
hasChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
hasChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
hasChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
hasChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
hasChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
hasChildren() - Method in class org.infinispan.tools.schema.TreeNode
 
hasClearOperation() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
hasComponentStarted() - Method in class org.infinispan.config.AbstractConfigurationBean
Tests whether the component this configuration bean intents to configure has already started.
hasComponentStarted() - Method in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
hasComponentStarted() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
hasComponentStarted() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
hasConsistentHashClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
hasElement(Object) - Method in class org.infinispan.tree.Fqn
 
hasFlag(Flag) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
hasFlag(Flag) - Method in class org.infinispan.commands.control.LockControlCommand
 
hasFlag(Flag) - Method in interface org.infinispan.commands.FlagAffectedCommand
Check whether a particular flag is present in the command
hasFlag(Flag) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
hasFlag(Flag) - Method in interface org.infinispan.context.FlagContainer
 
hasFlag(Flag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
hasFlag(Flag) - Method in class org.infinispan.context.impl.ImmutableContext
 
hasFlag(Flag) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
hasFlag(Flag) - Method in class org.infinispan.tree.TreeContext
 
hash - Variable in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
Hash - Interface in org.infinispan.commons.hash
Interface that governs implementations
hash(byte[]) - Method in interface org.infinispan.commons.hash.Hash
Hashes a byte array efficiently.
hash(int) - Method in interface org.infinispan.commons.hash.Hash
An incremental version of the hash function, that spreads a pre-calculated hash code, such as one derived from Object.hashCode().
hash(Object) - Method in interface org.infinispan.commons.hash.Hash
A helper that calculates the hashcode of an object, choosing the optimal mechanism of hash calculation after considering the type of the object (byte array, String or Object).
hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash2
 
hash(int) - Method in class org.infinispan.commons.hash.MurmurHash2
 
hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash2
 
hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
hash(int) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash3
 
hash(long[]) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hashes a byte array efficiently.
hash(int) - Method in class org.infinispan.commons.hash.MurmurHash3
 
hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash3
 
hash - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
hash() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
hash() - Method in interface org.infinispan.config.FluentConfiguration.ClusteringConfig
Deprecated. * Configure hash sub element
hash() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Configure hash sub element
hash() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Configure hash sub element
hash() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
Allows fine-tuning of rehashing characteristics.
hash() - Method in class org.infinispan.configuration.cache.HashConfiguration
The hash function in use.
hash(Hash) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
The hash function in use.
hash - Variable in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
hash(Object) - Static method in class org.infinispan.util.AbstractMap
 
HASH_FUNCTION_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
hashCode() - Method in class org.infinispan.cacheviews.CacheView
 
hashCode() - Method in class org.infinispan.cdi.interceptor.DefaultCacheKey
 
hashCode() - Method in class org.infinispan.client.hotrod.impl.BinaryVersionedValue
 
hashCode() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
hashCode() - Method in class org.infinispan.commands.control.LockControlCommand
 
hashCode() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
hashCode() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
hashCode() - Method in class org.infinispan.commands.read.MapReduceCommand
 
hashCode() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
hashCode() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
hashCode() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
hashCode() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
hashCode() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
hashCode() - Method in class org.infinispan.commands.write.InvalidateCommand
 
hashCode() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
hashCode() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
hashCode() - Method in class org.infinispan.commands.write.PutMapCommand
 
hashCode() - Method in class org.infinispan.commands.write.RemoveCommand
 
hashCode() - Method in class org.infinispan.commands.write.ReplaceCommand
 
hashCode() - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
hashCode() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
hashCode() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
hashCode() - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
hashCode() - Method in class org.infinispan.config.CustomInterceptorConfig
 
hashCode() - Method in class org.infinispan.config.GlobalConfiguration.AdvancedExternalizersType
Deprecated.  
hashCode() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
hashCode() - Method in class org.infinispan.config.GroupsConfiguration
 
hashCode() - Method in class org.infinispan.configuration.AbstractTypedPropertiesConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AbstractLockSupportCacheStoreConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.Configuration
 
hashCode() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.HashConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.L1Configuration
 
hashCode() - Method in class org.infinispan.configuration.cache.LoaderConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.LockingConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.SyncConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
 
hashCode() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
hashCode() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.MortalCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.TransientCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
hashCode() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
hashCode() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
hashCode() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
hashCode() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
hashCode() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
hashCode() - Method in class org.infinispan.distribution.ch.VirtualAddress
 
hashCode() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
hashCode() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
hashCode() - Method in class org.infinispan.io.GridFile
 
hashCode() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
hashCode() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
hashCode() - Method in class org.infinispan.loaders.modifications.ModificationsList
 
hashCode() - Method in class org.infinispan.loaders.modifications.Remove
 
hashCode() - Method in class org.infinispan.loaders.modifications.Store
 
hashCode() - Method in class org.infinispan.lucene.ChunkCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileListCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileMetadata
 
hashCode() - Method in class org.infinispan.lucene.FileReadLockKey
 
hashCode() - Method in class org.infinispan.marshall.MarshalledValue
 
hashCode() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
hashCode() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
hashCode() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
hashCode() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
hashCode() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
hashCode() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
hashCode() - Method in class org.infinispan.server.websocket.CacheListener.ChannelNotifyParams
 
hashCode() - Method in class org.infinispan.statetransfer.LockInfo
 
hashCode() - Method in class org.infinispan.tools.doclet.jmx.JmxComponent
 
hashCode() - Method in class org.infinispan.tools.schema.TreeNode
 
hashCode() - Method in class org.infinispan.transaction.AbstractEnlistmentAdapter
Invoked by TransactionManagers, make sure it's an efficient implementation.
hashCode() - Method in class org.infinispan.transaction.LocalTransaction
 
hashCode() - Method in class org.infinispan.transaction.RemoteTransaction
 
hashCode() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Implementing an efficient hashCode is critical for performance:
hashCode() - Method in class org.infinispan.transaction.tm.DummyTransaction
Must be defined for increased performance
hashCode() - Method in class org.infinispan.transaction.tm.DummyXid
 
hashCode() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
hashCode() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
hashCode() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
hashCode() - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
hashCode() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
 
hashCode() - Method in class org.infinispan.tree.Fqn
Returns a hash code with Fqn elements.
hashCode() - Method in class org.infinispan.tree.NodeImpl
 
hashCode() - Method in class org.infinispan.tree.NodeKey
 
hashCode() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
hashCode() - Method in class org.infinispan.util.ByteArrayKey
 
hashCode() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the hash code value for this Map, i.e., the sum of, for each key-value pair in the map, key.hashCode() ^ value.hashCode().
hashCode() - Method in class org.infinispan.util.ForwardingList
 
hashCode() - Method in class org.infinispan.util.SimpleImmutableEntry
 
hashCodeExcludingProperties() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
HashConfiguration - Class in org.infinispan.configuration.cache
Allows fine-tuning of rehashing characteristics.
HashConfigurationBuilder - Class in org.infinispan.configuration.cache
Allows fine-tuning of rehashing characteristics.
hashFunction - Variable in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
hashFunctionClass - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
hashFunctionClass(Class<? extends Hash>) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
hashFunctionClass(Class<? extends Hash>) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated. A fully qualified name of the class providing a hash function, used as a bit spreader and a general hash code generator.
hashRehashEnabledDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashRehashRpcTimeoutDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashRehashWaitDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hasJoinStarted() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
hasJoinStarted() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
hasLockAtOrigin(Collection<Object>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
hasLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
hasLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
hasLockedKey(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
hasLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
Returns true if the lock being tested is already held in the current scope, false otherwise.
hasLockedKey(Object) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
hasModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
hasModifications() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
hasModifications() - Method in interface org.infinispan.context.impl.TxInvocationContext
Were there any modifications performed within the tx's scope?
hasModifications() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
hasNext() - Method in class org.infinispan.container.DefaultDataContainer.EntryIterator
 
hasNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
hasNext() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
hasNext() - Method in class org.infinispan.query.clustered.DistributedIterator
 
hasNext() - Method in class org.infinispan.query.impl.AbstractIterator
 
hasNext() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
hasObservers(T, Annotation[]) - Method in class org.infinispan.cdi.event.AbstractEventBridge
 
hasPrevious() - Method in class org.infinispan.query.impl.AbstractIterator
 
hasTopologyInfo() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
hasTopologyInfo() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
HeaderParams - Class in org.infinispan.client.hotrod.impl.protocol
Hot Rod request header parameters
HeaderParams() - Constructor for class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
hexDump(byte[]) - Static method in class org.infinispan.util.Util
 
hexDump(ByteBuffer) - Static method in class org.infinispan.util.Util
 
hexIdHashCode(Object) - Static method in class org.infinispan.util.Util
Prints the identity hash code of the object passed as parameter in an hexadecimal format in order to safe space.
HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get hits.
hookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in interface org.infinispan.config.FluentGlobalConfiguration.ShutdownConfig
Deprecated.  
hookBehavior - Variable in class org.infinispan.config.GlobalConfiguration.ShutdownType
Deprecated.  
hookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
Deprecated.  
hookBehavior() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
hookBehavior(ShutdownHookBehavior) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
HOTROD_CLIENT_PROPERTIES - Static variable in class org.infinispan.client.hotrod.RemoteCacheManager
 
HOTROD_STRING_CHARSET - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
HotRodClientException - Exception in org.infinispan.client.hotrod.exceptions
Base class for exceptions reported by the hot rod client.
HotRodClientException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodConstants - Interface in org.infinispan.client.hotrod.impl.protocol
Defines constants defined by Hot Rod specifications.
HotRodOperation - Class in org.infinispan.client.hotrod.impl.operations
Generic Hot Rod operation.
HotRodOperation(Codec, Flag[], byte[], AtomicInteger) - Constructor for class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
HotRodOperations - Interface in org.infinispan.client.hotrod.impl.protocol
Defines the Hot Rod operations as described in the protocol spec: http://community.jboss.org/wiki/HotRodProtocol
HotRodTimeoutException - Exception in org.infinispan.client.hotrod.exceptions
Signals an remote timeout(due to locking) in the infinispan server.
HotRodTimeoutException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
hSearchQuery - Variable in class org.infinispan.query.impl.CacheQueryImpl
 
HtmlGenerator - Class in org.infinispan.tools.doclet.html
Generates HTML documents
HtmlGenerator(String, String, String, String, String, String, List<String>) - Constructor for class org.infinispan.tools.doclet.html.HtmlGenerator
 

I

icc - Variable in class org.infinispan.CacheImpl
 
icc - Variable in class org.infinispan.commands.read.MapReduceCommand
 
icc - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
icc - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
icc - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
icc - Variable in class org.infinispan.transaction.TransactionTable
 
id - Variable in class org.infinispan.config.AdvancedExternalizerConfig
 
identityConstraint(XSIdentityConstraint) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
Ids - Interface in org.infinispan.marshall
Indexes for object types.
ignoreClusterGetCall(CacheRpcCommand, String) - Method in interface org.infinispan.util.logging.Log
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in interface org.infinispan.commands.VisitableCommand
Similar to VisitableCommand.shouldInvoke(InvocationContext) but evaluated by InvocationContextInterceptor.
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.write.ClearCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.write.InvalidateCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.write.PutMapCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.write.RemoveCommand
 
IgnoreExtraResponsesValidityFilter - Class in org.infinispan.remoting.responses
A filter that only expects responses from an initial set of targets.
IgnoreExtraResponsesValidityFilter(Collection<Address>, Address) - Constructor for class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
 
ignoreModifications() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
ignoreModifications(boolean) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
ignoreModifications(boolean) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
ignoreModifications - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
ignoreModifications(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
ignoreModifications(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
ignoreModifications(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
ignoreModifications(Boolean) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
ignoringException(String, String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
ignoringManagedAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
immediateLockForWriting(L) - Method in class org.infinispan.loaders.LockSupportCacheStore
Same as LockSupportCacheStore.lockForWriting(Object), but with 0 timeout.
IMMORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
IMMORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
ImmortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is immortal/cannot expire
ImmortalCacheEntry(Object, ImmortalCacheValue) - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry
 
ImmortalCacheEntry(Object, Object) - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry
 
ImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
ImmortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
ImmortalCacheValue - Class in org.infinispan.container.entries
An immortal cache value, to correspond with ImmortalCacheEntry
ImmortalCacheValue(Object) - Constructor for class org.infinispan.container.entries.ImmortalCacheValue
 
ImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
ImmortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
IMMUTABLE_MAP - Static variable in interface org.infinispan.marshall.Ids
 
immutableCollectionCopy(Collection<T>) - Static method in class org.infinispan.util.Immutables
Creates a new immutable copy of the specified Collection.
immutableCollectionWrap(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Wraps a collection with an immutable collection.
ImmutableContext - Class in org.infinispan.context.impl
This context is a non-context for operations such as eviction which are not related to the method invocation which caused them.
immutableEntry(Map.Entry<K, V>) - Static method in class org.infinispan.util.Immutables
Wraps a Map.Entry} with an immutable Map.Entry}.
immutableInternalCacheEntry(InternalCacheEntry) - Static method in class org.infinispan.util.Immutables
Wraps a InternalCacheEntry} with an immutable InternalCacheEntry}.
immutableListConvert(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Converts a Collection to an immutable List by copying it.
ImmutableListCopy<E> - Class in org.infinispan.util
A lightweight, read-only copy of a List.
ImmutableListCopy() - Constructor for class org.infinispan.util.ImmutableListCopy
Constructs a new ImmutableListCopy.
ImmutableListCopy(Collection<? extends E>) - Constructor for class org.infinispan.util.ImmutableListCopy
Only one copy constructor since the list is immutable.
ImmutableListCopy(E[]) - Constructor for class org.infinispan.util.ImmutableListCopy
Assumes that the array passed in is "safe", i.e., is not referenced from elsewhere.
ImmutableListCopy(Collection<? extends E>, Collection<? extends E>) - Constructor for class org.infinispan.util.ImmutableListCopy
Utility constructors to allow combining collections
immutableListCopy(List<T>) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the list.
immutableListMerge(List<? extends T>, List<? extends T>) - Static method in class org.infinispan.util.Immutables
Creates a new immutable list containing the union (combined entries) of both lists.
immutableListWrap(T...) - Static method in class org.infinispan.util.Immutables
Wraps an array with an immutable list.
immutableMapCopy(Map<K, V>) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the specified map.
immutableMapWrap(Map<? extends K, ? extends V>) - Static method in class org.infinispan.util.Immutables
Wraps a map with an immutable map.
ImmutableMarshalledValueByteStream - Class in org.infinispan.io
A byte stream that is immutable.
ImmutableMarshalledValueByteStream(byte[]) - Constructor for class org.infinispan.io.ImmutableMarshalledValueByteStream
 
Immutables - Class in org.infinispan.util
Factory for generating immutable type wrappers.
Immutables() - Constructor for class org.infinispan.util.Immutables
 
Immutables.Immutable - Interface in org.infinispan.util
 
Immutables.ImmutableMapWrapperExternalizer - Class in org.infinispan.util
 
Immutables.ImmutableMapWrapperExternalizer() - Constructor for class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
immutableSetConvert(Collection<? extends T>) - Static method in class org.infinispan.util.Immutables
Converts a Collections into an immutable Set by copying it.
immutableSetCopy(Set<T>) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the specified set.
immutableSetWrap(Set<? extends T>) - Static method in class org.infinispan.util.Immutables
Wraps a set with an immutable set.
immutableTypedPropreties(TypedProperties) - Static method in class org.infinispan.util.Immutables
Creates an immutable copy of the properties.
IN_DOUBT_TX_INFO - Static variable in interface org.infinispan.marshall.Ids
 
InboundInvocationHandler - Interface in org.infinispan.remoting
A globally scoped component, that is able to locate named caches and invoke remotely originating calls on the appropriate cache.
inboundInvocationHandler - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
InboundInvocationHandlerImpl - Class in org.infinispan.remoting
Sets the cache interceptor chain on an RPCCommand before calling it to perform
InboundInvocationHandlerImpl() - Constructor for class org.infinispan.remoting.InboundInvocationHandlerImpl
 
includeKey(Object, Set<Object>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
IncorrectListenerException - Exception in org.infinispan.notifications
Thrown when an incorrectly annotated class is added as a cache listener using the Listenable.addListener(Object) API.
IncorrectListenerException(String) - Constructor for exception org.infinispan.notifications.IncorrectListenerException
 
increment(IncrementableEntryVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
increment(IncrementableEntryVersion) - Method in interface org.infinispan.container.versioning.VersionGenerator
 
increment() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Equivalent to add(1).
IncrementableEntryVersion - Interface in org.infinispan.container.versioning
An interface indicating that a version of this type can be incremented.
IncrementalVersionableEntryFactoryImpl - Class in org.infinispan.container
An entry factory that is capable of dealing with SimpleClusteredVersions.
IncrementalVersionableEntryFactoryImpl() - Constructor for class org.infinispan.container.IncrementalVersionableEntryFactoryImpl
 
index - Variable in class org.infinispan.config.CustomInterceptorConfig
 
index() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
index(int) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Specifies a position in the interceptor chain to place the new interceptor.
index - Variable in class org.infinispan.query.impl.AbstractIterator
 
indexing() - Method in class org.infinispan.configuration.cache.Configuration
 
indexing() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
indexing() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
IndexingConfiguration - Class in org.infinispan.configuration.cache
Configures indexing of entries in the cache for searching.
IndexingConfigurationBuilder - Class in org.infinispan.configuration.cache
Configures indexing of entries in the cache for searching.
indexLocalOnly - Variable in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
indexLocalOnly(Boolean) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
indexLocalOnly(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.IndexingConfig
Deprecated. If true, only index changes made locally, ignoring remote changes.
indexLocalOnly() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
If true, only index changes made locally, ignoring remote changes.
indexLocalOnly(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
If true, only index changes made locally, ignoring remote changes.
indexOf(Object) - Method in class org.infinispan.util.ForwardingList
 
indexOf(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
InDoubtTxInfoImpl - Class in org.infinispan.transaction.xa.recovery
 
InDoubtTxInfoImpl(Xid, Long, Integer) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
InDoubtTxInfoImpl(Xid, long, Set<Integer>) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
InDoubtTxInfoImpl(Xid, long) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
InDoubtTxInfoImpl.Externalizer - Class in org.infinispan.transaction.xa.recovery
 
InDoubtTxInfoImpl.Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
 
InequalVersionComparisonResult - Enum in org.infinispan.container.versioning
Versions can be compared to each other to result in one version being before, after or at the same time as another version.
INFINISPAN_WS_JS_FILENAME - Static variable in class org.infinispan.server.websocket.WebSocketServer
 
InfinispanAnnotationProvider - Class in org.infinispan.cdi
JCache AnnotationProvider implementation.
InfinispanAnnotationProvider() - Constructor for class org.infinispan.cdi.InfinispanAnnotationProvider
 
infinispanClasses() - Static method in class org.infinispan.util.ClassFinder
 
infinispanClasses(String) - Static method in class org.infinispan.util.ClassFinder
 
InfinispanCollections - Class in org.infinispan.util
Static helpers for Infinispan-specific collections
InfinispanCollections() - Constructor for class org.infinispan.util.InfinispanCollections
 
InfinispanCollections.Function<E,T> - Interface in org.infinispan.util
A function that converts a type into another one.
InfinispanCollections.MapMakerFunction<K,V,E> - Interface in org.infinispan.util
A function that converts an entry into a key/value pair for use in a map.
InfinispanConfiguration - Class in org.infinispan.config
Deprecated. Use Parser instead
InfinispanContainerCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.config
 
InfinispanContainerCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.config.InfinispanContainerCacheManagerBeanDefinitionParser
 
InfinispanDefaultCacheFactoryBean<K,V> - Class in org.infinispan.spring.support
A FactoryBean for creating a native default Infinispan org.infinispan.Cache , delegating to a configurable org.infinispan.manager.CacheContainer.
InfinispanDefaultCacheFactoryBean() - Constructor for class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
 
InfinispanDemo - Class in org.infinispan.demo
Run it with -Djgroups.bind_addr=127.0.0.1 -Djava.net.preferIPv4Stack=true
InfinispanDemo(String) - Constructor for class org.infinispan.demo.InfinispanDemo
 
InfinispanDemo.AlternateColorTable - Class in org.infinispan.demo
 
InfinispanDemo.AlternateColorTable() - Constructor for class org.infinispan.demo.InfinispanDemo.AlternateColorTable
 
InfinispanDemo.CachedDataTableModel - Class in org.infinispan.demo
 
InfinispanDemo.CachedDataTableModel() - Constructor for class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
InfinispanDemo.CacheListener - Class in org.infinispan.demo
 
InfinispanDemo.CacheListener() - Constructor for class org.infinispan.demo.InfinispanDemo.CacheListener
 
InfinispanDemo.ClusterTableModel - Class in org.infinispan.demo
 
InfinispanDemo.ClusterTableModel() - Constructor for class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
InfinispanDirectory - Class in org.infinispan.lucene
An implementation of Lucene's Directory which uses Infinispan to store Lucene indexes.
InfinispanDirectory(Cache<?, ?>, Cache<?, ?>, String, LockFactory, int, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<?, ?>, String, int, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String, int) - Constructor for class org.infinispan.lucene.InfinispanDirectory
This constructor assumes that three different caches are being used with specialized configurations for each cache usage
InfinispanDirectory(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanDirectory(Cache<?, ?>) - Constructor for class org.infinispan.lucene.InfinispanDirectory
 
InfinispanEmbeddedCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.config
 
InfinispanEmbeddedCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
 
InfinispanEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.support.embedded
A FactoryBean for creating an Infinispan EmbeddedCacheManager instance.
InfinispanEmbeddedCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
 
InfinispanExtension - Class in org.infinispan.cdi
The Infinispan CDI extension class.
InfinispanFluDemo - Class in org.infinispan.ec2demo
 
InfinispanFluDemo() - Constructor for class org.infinispan.ec2demo.InfinispanFluDemo
 
InfinispanIndexInput - Class in org.infinispan.lucene
Responsible for reading from InfinispanDirectory
InfinispanIndexInput(AdvancedCache<?, ?>, FileCacheKey, FileMetadata, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanIndexInput
 
InfinispanIndexOutput - Class in org.infinispan.lucene
Responsible for writing to a Directory
InfinispanIndexOutput(AdvancedCache<?, ?>, AdvancedCache<?, ?>, FileCacheKey, int, FileListOperations) - Constructor for class org.infinispan.lucene.InfinispanIndexOutput
 
InfinispanNamedEmbeddedCacheFactoryBean<K,V> - Class in org.infinispan.spring.support.embedded
A FactoryBean for creating a native named Infinispan org.infinispan.Cache, delegating to a configurable org.infinispan.manager.EmbeddedCacheManager.
InfinispanNamedEmbeddedCacheFactoryBean() - Constructor for class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
InfinispanNamedRemoteCacheFactoryBean<K,V> - Class in org.infinispan.spring.support.remote
A FactoryBean for creating a native named Infinispan org.infinispan.Cache, delegating to a configurable oorg.infinispan.client.hotrod.RemoteCacheManagerr.
InfinispanNamedRemoteCacheFactoryBean() - Constructor for class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
 
InfinispanNamespaceHandler - Class in org.infinispan.spring.config
NamespaceHandler for Infinispan-based caches.
InfinispanNamespaceHandler() - Constructor for class org.infinispan.spring.config.InfinispanNamespaceHandler
 
InfinispanNamespaceUtils - Class in org.infinispan.spring.config
 
InfinispanNamespaceUtils() - Constructor for class org.infinispan.spring.config.InfinispanNamespaceUtils
 
InfinispanRemoteCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.config
 
InfinispanRemoteCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.config.InfinispanRemoteCacheManagerBeanDefinitionParser
 
InfinispanRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.support.remote
A FactoryBean for creating an Infinispan RemoteCacheManager instance.
InfinispanRemoteCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
 
Influenza_N_P_CR_Element - Class in org.infinispan.ec2demo
 
Influenza_N_P_CR_Element() - Constructor for class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
Influenza_Parser - Class in org.infinispan.ec2demo
 
Influenza_Parser() - Constructor for class org.infinispan.ec2demo.Influenza_Parser
 
InfluenzaDataLoader - Class in org.infinispan.ec2demo
 
InfluenzaDataLoader() - Constructor for class org.infinispan.ec2demo.InfluenzaDataLoader
 
InfluenzaVirusCache - Class in org.infinispan.ec2demo
 
InfluenzaVirusCache(CacheBuilder) - Constructor for class org.infinispan.ec2demo.InfluenzaVirusCache
 
init(CacheManagerNotifier, Transport, ExecutorService, GlobalConfiguration) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
init(Map<SocketAddress, Set<Integer>>, int, int) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
init(ConfigurationProperties, ClassLoader) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
init(Map<SocketAddress, Set<Integer>>, int, int) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
init(Marshaller, ExecutorService, OperationsFactory, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
init(CacheViewsManager) - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
init(StateTransferManager, Configuration, DataContainer, CommandsFactory) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
init(Cache<Object, Object>) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
init(CommandsFactory, InterceptorChain, InvocationContextContainer, DistributionManager, Address) - Method in class org.infinispan.commands.read.MapReduceCommand
 
init(InterceptorChain, InvocationContextContainer) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
init(RecoveryManager) - Method in class org.infinispan.commands.remote.recovery.RecoveryCommand
 
init(TransactionTable, LockManager, RecoveryManager) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
init(InterceptorChain, InvocationContextContainer, TransactionTable) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.ClearCommand
 
init(Configuration, DistributionManager, CacheNotifier, DataContainer) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.PutMapCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.RemoveCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.ReplaceCommand
 
init() - Method in class org.infinispan.container.EntryFactoryImpl
 
init(Cache<?, ?>, Transport) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
init(TransactionManager, TransactionTable) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
init(ServletConfig) - Method in class org.infinispan.demos.gridfs.CacheManagerHolder
 
init(Configuration, RpcManager, CommandsFactory, CacheNotifier, StateTransferManager) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
init(Configuration, RpcManager, CommandsFactory, ExecutorService, ScheduledExecutorService) - Method in class org.infinispan.distribution.L1ManagerImpl
 
init(ServletConfig) - Method in class org.infinispan.ec2demo.web.CacheSearchServlet
 
init(RpcManager) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
init() - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
init(CacheLoaderManager, InternalEntryFactory, TransactionManager) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
init(EntryFactory, DataContainer, ClusteringDependentLogic, CommandsFactory) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
init(TransactionManager, ComponentRegistry, TransactionTable, InvocationContextContainer) - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
init(DataContainer, RpcManager) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
init(DistributionManager, DataContainer, Configuration, RpcManager) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
init(CommandsFactory) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
init(StateTransferLock, CommandsFactory) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
init(StateTransferLock, Configuration) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
init(TransactionTable, Configuration, TransactionCoordinator) - Method in class org.infinispan.interceptors.TxInterceptor
 
init(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.AbstractCacheLoader
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.AbstractCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Used to initialize a cache loader.
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in interface org.infinispan.loaders.CacheLoader
Used to initialize a cache loader.
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller, BlobStoreContext, BlobStore, AsyncBlobStore, boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.file.FileCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
init(CacheLoaderConfig, Cache<?, ?>, StreamingMarshaller) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
init(Cache<?, ?>, HSQuery, UUID, int) - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
init() - Method in class org.infinispan.spring.config.InfinispanNamespaceHandler
 
init(Configuration, RpcManager, CommandsFactory, DataContainer, InterceptorChain, InvocationContextContainer, CacheLoaderManager, CacheNotifier, StateTransferLock, CacheViewsManager, TransactionTable, LockContainer<?>) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
init(DistributionManager) - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
init(Configuration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
init(CommandsFactory, InvocationContextContainer, InterceptorChain, TransactionTable, Configuration) - Method in class org.infinispan.transaction.TransactionCoordinator
 
init(RecoveryManager) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
init(RpcManager, CommandsFactory, TransactionTable, TransactionCoordinator, TransactionFactory) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
init(Configuration, EmbeddedCacheManager, RpcManager) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
init(boolean, boolean, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
init(RecoveryManager) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
init() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
initChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
initChunkSizeFromMetadata() - Method in class org.infinispan.io.GridFile
 
initForWriting() - Method in class org.infinispan.atomic.AtomicHashMap
Initializes the delta instance to start recording changes.
initialize(InvocationContextContainer, CommandsFactory, InternalEntryFactory, InterceptorChain, DistributionManager, TransactionTable) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
initialize(CacheNotifier, RecoveryManager) - Method in class org.infinispan.commands.tx.PrepareCommand
 
initialize(CacheNotifier) - Method in class org.infinispan.commands.write.EvictCommand
 
initialize(EvictionManager, PassivationManager, InternalEntryFactory) - Method in class org.infinispan.container.DefaultDataContainer
 
initialize(ScheduledExecutorService, Configuration, DataContainer, CacheLoaderManager, CacheNotifier) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
initialize(Iterable<ModuleMetadataFileFinder>, ClassLoader) - Static method in class org.infinispan.factories.components.ComponentMetadataRepo
Initializes this repository.
initialize(VersionGenerator) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
initialize(Cache<?, ?>, GlobalConfiguration) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
initialize(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
initialize(StreamingMarshaller, ExecutorService, InboundInvocationHandler, CacheManagerNotifier) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
initialize(StreamingMarshaller, ExecutorService, InboundInvocationHandler, CacheManagerNotifier) - Method in interface org.infinispan.remoting.transport.Transport
Initializes the transport with global cache configuration and transport-specific properties.
initialize(RpcManager, Configuration, InvocationContextContainer, InterceptorChain, CacheNotifier, TransactionFactory, EmbeddedCacheManager, TransactionCoordinator, TransactionSynchronizationRegistry, CommandsFactory, ClusteringDependentLogic) - Method in class org.infinispan.transaction.TransactionTable
 
initialize(RecoveryManager) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
initializeReplicableCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Initializes a ReplicableCommand read from a data stream with components specific to the target cache instance.
initializeReplicableCommand(ReplicableCommand, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
initializeReplicableCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.commands.module.ModuleCommandInitializer
Initializes a command constructed using ModuleCommandFactory.fromStream(byte, Object[]) with necessary named-cache-specific components.
initializeReplicableCommand(ReplicableCommand, boolean) - Method in class org.infinispan.query.CommandInitializer
 
initialRetryWaitTime - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
initialRetryWaitTime(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
initialRetryWaitTime(Long) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. Initial wait time when backing off before retrying state transfer retrieval
initialRetryWaitTimeDeprecated() - Method in interface org.infinispan.util.logging.Log
 
initialView - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
initLocks(int) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
initLocks(int) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
initLocks(int) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
inject(EmbeddedCacheManager, GlobalComponentRegistry, Map<Byte, ModuleCommandFactory>) - Method in class org.infinispan.commands.RemoteCommandsFactory
 
inject(ComponentRegistry) - Method in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
inject(ComponentRegistry) - Method in class org.infinispan.config.Configuration
Deprecated.  
inject(CacheLoaderManager, CacheNotifier, Configuration, DataContainer) - Method in class org.infinispan.eviction.PassivationManagerImpl
 
Inject - Annotation Type in org.infinispan.factories.annotations
Used to annotate a method as one that is used to inject a registered component into another component.
inject(DistributionManager, Transport) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
inject(AdvancedCache<Object, Object>, StreamingMarshaller, Configuration, InvocationContextContainer, TransactionManager) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
inject(Configuration, InvocationContextContainer, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.CacheMarshaller
 
inject(ClassLoader, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.GlobalMarshaller
 
inject(RemoteCommandsFactory, GlobalComponentRegistry, StreamingMarshaller) - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
inject(ExternalizerTable, ClassLoader, InvocationContextContainer, GlobalConfiguration) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
inject(Configuration, ClassLoader, InvocationContextContainer, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
inject(GlobalComponentRegistry, EmbeddedCacheManager, Transport, GlobalConfiguration, CacheViewsManager) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
inject(DistributionManager) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
injectCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
injectComponents(Configuration) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
injectComponents(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
injectDependencies(EvictionManager, InvocationContextContainer, CommandsFactory, InterceptorChain, Configuration, CacheNotifier, ComponentRegistry, TransactionManager, BatchContainer, RpcManager, DataContainer, StreamingMarshaller, ResponseGenerator, DistributionManager, EmbeddedCacheManager, StateTransferManager, ExecutorService, TransactionTable, RecoveryManager, TransactionCoordinator, LockManager) - Method in class org.infinispan.CacheImpl
 
injectDependencies(DataContainer, Configuration, CacheNotifier) - Method in class org.infinispan.container.EntryFactoryImpl
 
injectDependencies() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Injects dependencies into this component.
injectDependencies(CacheLoaderManager, EntryFactory, CacheNotifier) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
injectDependencies(DistributionManager, StateTransferLock, CommandsFactory, DataContainer, EntryFactory, L1Manager, LockManager) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
injectDependencies(CommandsFactory) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
injectDependencies(CacheNotifier) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
injectDependencies(TransactionManager, TransactionSynchronizationRegistry, ExecutorService) - Method in class org.infinispan.query.backend.LocalQueryInterceptor
 
injectDependencies(ExecutorService) - Method in class org.infinispan.query.backend.QueryInterceptor
 
injectDependencies(ScheduledExecutorService, RpcManager, Configuration, CommandsFactory, Cache) - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
injectDependencies(ScheduledExecutorService, RpcManager, Configuration, CommandsFactory, String) - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
injectDependencies(Transport, Configuration, ReplicationQueue, CommandsFactory, ExecutorService, CacheViewsManager) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
injectDependencies(Configuration) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
injectDependencies(Configuration, LockContainer<?>) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
injectMarshaller(StreamingMarshaller, DistributionManager) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
injectMarshaller(StreamingMarshaller, InternalEntryFactory) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Inserts a new Bucket in the storage system.
insertBucket(Bucket) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
INSTANCE - Static variable in class org.infinispan.cdi.interceptor.literal.CachePutLiteral
 
INSTANCE - Static variable in class org.infinispan.cdi.interceptor.literal.CacheRemoveAllLiteral
 
INSTANCE - Static variable in class org.infinispan.cdi.interceptor.literal.CacheRemoveEntryLiteral
 
INSTANCE - Static variable in class org.infinispan.cdi.interceptor.literal.CacheResultLiteral
 
INSTANCE - Static variable in class org.infinispan.context.impl.ImmutableContext
 
instance() - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash.Externalizer
 
instance() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash.Externalizer
 
instance() - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash.Externalizer
 
instance - Variable in class org.infinispan.marshall.MarshalledValue
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsureResponse
 
INSTANCE - Static variable in class org.infinispan.tree.FqnComparator
 
interceptor - Variable in class org.infinispan.config.CustomInterceptorConfig
 
interceptor() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
interceptor(CommandInterceptor) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
An instance of the new custom interceptor to add to the configuration.
interceptorChain - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
InterceptorChain - Class in org.infinispan.interceptors
Knows how to build and manage an chain of interceptors.
InterceptorChain(CommandInterceptor) - Constructor for class org.infinispan.interceptors.InterceptorChain
Constructs an interceptor chain having the supplied interceptor as first.
interceptorChain - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
InterceptorChainFactory - Class in org.infinispan.factories
Factory class that builds an interceptor chain based on cache configuration.
InterceptorChainFactory() - Constructor for class org.infinispan.factories.InterceptorChainFactory
 
InterceptorConfiguration - Class in org.infinispan.configuration.cache
Describes a custom interceptor
InterceptorConfiguration.Position - Enum in org.infinispan.configuration.cache
Positional placing of a new custom interceptor
InterceptorConfigurationBuilder - Class in org.infinispan.configuration.cache
This builder defines details of a specific custom interceptor.
interceptors() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
This specifies a list of InterceptorConfiguration instances to be referenced when building the interceptor chain.
InternalCacheEntry - Interface in org.infinispan.container.entries
Interface for internal cache entries that expose whether an entry has expired.
InternalCacheFactory<K,V> - Class in org.infinispan.factories
An internal factory for constructing Caches.
InternalCacheFactory() - Constructor for class org.infinispan.factories.InternalCacheFactory
 
InternalCacheValue - Interface in org.infinispan.container.entries
A representation of an InternalCacheEntry that does not have a reference to the key.
InternalEntryFactory - Interface in org.infinispan.container
A factory for InternalCacheEntry and InternalCacheValue instances.
InternalEntryFactoryImpl - Class in org.infinispan.container
An implementation that generates non-versioned entries
InternalEntryFactoryImpl() - Constructor for class org.infinispan.container.InternalEntryFactoryImpl
 
interruptedAcquiringLock(long, InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedWaitingForCoordinator(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
intValue() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
INVALID_MAGIC_OR_MESSAGE_ID_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
invalidate(InvocationContext, Object) - Method in class org.infinispan.commands.write.InvalidateCommand
 
invalidate() - Method in class org.infinispan.transaction.RemoteTransaction
 
invalidateAcrossCluster(boolean, InvocationContext, Object[], boolean, Object) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
InvalidateCommand - Class in org.infinispan.commands.write
Removes an entry from memory.
InvalidateCommand() - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateCommand(CacheNotifier, Object...) - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateCommand(CacheNotifier, Collection<Object>) - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
invalidateKeys(List<Object>) - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
InvalidateL1Command - Class in org.infinispan.commands.write
Invalidates an entry in a L1 cache (used with DIST mode)
InvalidateL1Command() - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(boolean, DataContainer, Configuration, DistributionManager, CacheNotifier, Object...) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(boolean, DataContainer, Configuration, DistributionManager, CacheNotifier, Collection<Object>) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(Address, boolean, DataContainer, Configuration, DistributionManager, CacheNotifier, Collection<Object>) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
invalidateModifiedEntry(CacheEntryModifiedEvent<ByteArrayKey, CacheValue>) - Method in class org.infinispan.demo.nearcache.server.MessagingHotRodDemo.InvalidationProducer
 
invalidateRemovedEntry(CacheEntryEvent<ByteArrayKey, CacheValue>) - Method in class org.infinispan.demo.nearcache.server.MessagingHotRodDemo.InvalidationProducer
 
InvalidationInterceptor - Class in org.infinispan.interceptors
This interceptor acts as a replacement to the replication interceptor when the CacheImpl is configured with ClusteredSyncMode as INVALIDATE.
InvalidationInterceptor() - Constructor for class org.infinispan.interceptors.InvalidationInterceptor
 
InvalidationInterceptor.InvalidationFilterVisitor - Class in org.infinispan.interceptors
 
InvalidationInterceptor.InvalidationFilterVisitor(int) - Constructor for class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
invalidationThreshold - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.  
invalidationThreshold(Integer) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
invalidationThreshold(Integer) - Method in interface org.infinispan.config.FluentConfiguration.L1Config
Deprecated.  Determines whether a multicast or a web of unicasts are used when performing L1 invalidations.
invalidationThreshold() - Method in class org.infinispan.configuration.cache.L1Configuration
Determines whether a multicast or a web of unicasts are used when performing L1 invalidations.
invalidationThreshold(int) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Determines whether a multicast or a web of unicasts are used when performing L1 invalidations.
invalidAttributeValue(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an invalid XML attribute value.
invalidKey2StringMapper(String, String) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
invalidMagicNumber(short, short) - Method in interface org.infinispan.client.hotrod.logging.Log
 
invalidManagedAttributeMethod(String) - Method in interface org.infinispan.util.logging.Log
 
invalidMessageId(long, long) - Method in interface org.infinispan.client.hotrod.logging.Log
 
invalidRemoteTxReturnValue() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
This is what is returned to remote callers when an invalid RemoteTransaction is encountered.
invalidRemoteTxReturnValue() - Method in class org.infinispan.commands.tx.CommitCommand
 
InvalidResponse - Class in org.infinispan.remoting.responses
An invalid response
InvalidResponse() - Constructor for class org.infinispan.remoting.responses.InvalidResponse
 
InvalidResponseException - Exception in org.infinispan.client.hotrod.exceptions
Signals an internal protocol error.
InvalidResponseException() - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in interface org.infinispan.util.logging.Log
 
InvalidTransactionException - Exception in org.infinispan.transaction.xa
Thrown if an operation is to be performed on an invalid transaction context.
InvalidTransactionException() - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
InvalidTransactionException(Throwable) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
InvalidTransactionException(String) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
InvalidTransactionException(String, Throwable) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
invocationBatching() - Method in class org.infinispan.configuration.cache.Configuration
 
invocationBatching() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
invocationBatching() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
InvocationBatchingConfiguration - Class in org.infinispan.configuration.cache
 
InvocationBatchingConfigurationBuilder - Class in org.infinispan.configuration.cache
 
InvocationContext - Interface in org.infinispan.context
A context that contains information pertaining to a given invocation.
InvocationContextContainer - Interface in org.infinispan.context
Manages the association between an InvocationContext and the calling thread.
InvocationContextFlagsOverride - Class in org.infinispan.context
Wraps an existing InvocationContext without changing the context directly but making sure the specified flags are considered enabled.
InvocationContextFlagsOverride(InvocationContext, Set<Flag>) - Constructor for class org.infinispan.context.InvocationContextFlagsOverride
Wraps an existing InvocationContext without changing the context directly but making sure the specified flags are considered enabled.
InvocationContextInterceptor - Class in org.infinispan.interceptors
 
InvocationContextInterceptor() - Constructor for class org.infinispan.interceptors.InvocationContextInterceptor
 
invocationsAllowed(boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Asserts whether invocations are allowed on the cache or not.
invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.InterceptorChain
Walks the command through the interceptor chain.
invoke(String, Object[], String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
invoke(Object) - Method in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
invokeAccessibly(Object, Method, Object[]) - Static method in class org.infinispan.util.ReflectionUtil
Invokes a method using reflection, in an accessible manner (by using AccessibleObject.setAccessible(boolean)
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.distexec.DefaultExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeLocally(DefaultExecutorService.DistributedRunnableFuture<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
invokeNextAndCommitIf1Pc(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
invokeNextInterceptor(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Invokes the next interceptor in the chain.
invokeOperation(String, Configuration) - Method in class org.infinispan.rhq.CacheComponent
Invoke operations on the Cache MBean instance
invoker - Variable in class org.infinispan.CacheImpl
 
invoker - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
invoker - Variable in class org.infinispan.distexec.DefaultExecutorService
 
invokeRemoteCommand(Address, ReplicableCommand, ResponseMode, long, boolean, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
invokeRemoteCommands(List<Address>, ReplicableCommand, ResponseMode, long, boolean, boolean, RspFilter, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes an RPC call on other caches in the cluster.
invokeRemotely(Collection<Address>, ReplicableCommand, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to a specified set of recipients
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Broadcasts an RPC command to a specified set of recipients
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in interface org.infinispan.remoting.transport.Transport
Invokes an RPC call on other caches in the cluster.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean) except that the task is passed to the transport executor and a Future is returned.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture) except that you can specify a timeout.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, boolean, org.infinispan.util.concurrent.NotifyingNotifiableFuture, long) except that you can specify a response mode.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
ioErrorIntegratingState(IOException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
ioErrorStoringKeys(IOException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
ioErrorUnmarshalling(IOException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
isAbsolute() - Method in class org.infinispan.io.GridFile
 
isAcceptable(Response, Address) - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
isAcceptable(Response, Address) - Method in class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
 
isAcceptable(Response, Address) - Method in interface org.infinispan.remoting.rpc.ResponseFilter
Determines whether a response from a given sender should be added to the response list of the request
isAcceptable(Object, Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
 
isAdjacent(Address, Address) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
Two hashes are adjacent if they are next to each other in the consistent hash.
isAffectedByRehash(Object) - Method in interface org.infinispan.distribution.DistributionManager
Tests whether a given key is affected by a rehash that may be in progress.
isAffectedByRehash(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
isAfterFirst() - Method in class org.infinispan.query.impl.AbstractIterator
 
isAfterFirst() - Method in interface org.infinispan.query.QueryIterator
 
isAllowDuplicateDomains() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
isAlwaysProvideInMemoryState() - Method in class org.infinispan.config.Configuration
Deprecated.  
isAlwaysProvideInMemoryState() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
isAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
Tests whether an annotation is present on a class.
isAssignableFrom(List<Class<?>>, Class<?>) - Static method in class org.infinispan.util.ClassFinder
 
isAssignableFrom(Class<?>) - Static method in class org.infinispan.util.ClassFinder
 
isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isAsyncMarshalling() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
isAutoCreateKeyspace() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
isBeforeLast() - Method in class org.infinispan.query.impl.AbstractIterator
 
isBeforeLast() - Method in interface org.infinispan.query.QueryIterator
 
isCacheLoaderPassivation() - Method in class org.infinispan.config.Configuration
Deprecated.  
isCacheLoaderPreload() - Method in class org.infinispan.config.Configuration
Deprecated.  
isCacheLoaderShared() - Method in class org.infinispan.config.Configuration
Deprecated.  
isCacheReady() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
A test to check whether the cache is in its started state.
isCancelled() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
isCancelled() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
isCausedByALocalWrite(Address) - Method in class org.infinispan.commands.write.InvalidateL1Command
Returns true if the write that caused the invalidation was performed on this node.
isChanged() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isChanged() - Method in interface org.infinispan.container.entries.CacheEntry
 
isChanged() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isChanged() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isChildOf(String, String) - Static method in class org.infinispan.io.GridFile
Verifies whether child is a child (dir or file) of parent
isChildOf(Fqn) - Method in class org.infinispan.tree.Fqn
Returns true if this Fqn is child of parentFqn.
isChildOrEquals(Fqn) - Method in class org.infinispan.tree.Fqn
Returns true if this Fqn is equals or the child of parentFqn.
isClustered() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.  
isClustered() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isCompletionFailed() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
Returns true if this transaction failed during 2nd phase of 2PC(prepare or commit).
isCompress() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
isConditional() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
isConditional() - Method in class org.infinispan.commands.write.ClearCommand
 
isConditional() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isConditional() - Method in class org.infinispan.commands.write.PutMapCommand
 
isConditional() - Method in class org.infinispan.commands.write.RemoveCommand
 
isConditional() - Method in class org.infinispan.commands.write.ReplaceCommand
 
isConditional() - Method in interface org.infinispan.commands.write.WriteCommand
Certain commands only work based on a certain condition or state of the cache.
isContextFlagSet(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Tests whether a context flag is set.
isCoordinator() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
isCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
isCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
isCoordinator - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
isCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
isCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
isCreated() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isCreated() - Method in interface org.infinispan.container.entries.CacheEntry
 
isCreated() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isCreated() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isCreateTableOnStart() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
isCustomConsistentHashClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
isCustomHashFunctionClass() - Method in class org.infinispan.config.Configuration
Deprecated.  
isDeadlockDetectionEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isDefaultRunning() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
isDefaultRunning() - Method in class org.infinispan.manager.DefaultCacheManager
 
isDefaultRunning() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Tests whether the default cache is running.
isDirectChildOf(Fqn) - Method in class org.infinispan.tree.Fqn
Returns true if this Fqn is a direct child of a given Fqn.
isDirectory() - Method in class org.infinispan.io.GridFile
 
isDirectory() - Method in class org.infinispan.io.GridFile.Metadata
 
isDistributed() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.  
isDistributed() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isDistributed() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
isDone() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
isDone() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
isDone() - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
isDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
isDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
isDone() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
isDone() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
isDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
isDrainNextCallWithoutLock() - Method in class org.infinispan.distribution.RemoteTransactionLogDetails
 
isDropTableOnExit() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
isEagerLockingSingleNodeInUse() - Method in class org.infinispan.config.Configuration
Deprecated. this is deprecated as starting with Infinispan 5.1 a single lock is always acquired disregarding the number of owner.
isEagerLockSingleNode() - Method in class org.infinispan.config.Configuration
Deprecated. starting with Infinispan 5.1 single node locking is used by default
isEagerLockSingleNode() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
isEmpty() - Method in class org.infinispan.AbstractDelegatingCache
 
isEmpty() - Method in class org.infinispan.atomic.AtomicHashMap
 
isEmpty() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
isEmpty() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
isEmpty() - Method in class org.infinispan.CacheImpl
 
isEmpty() - Method in class org.infinispan.cacheviews.CacheView
 
isEmpty() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
isEmpty() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
isEmpty() - Method in class org.infinispan.DecoratedCache
 
isEmpty() - Method in class org.infinispan.loaders.bucket.Bucket
 
isEmpty() - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
isEmpty() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
isEmpty() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
isEmpty() - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
isEmpty() - Method in class org.infinispan.util.FastCopyHashMap
 
isEmpty() - Method in class org.infinispan.util.ForwardingList
 
isEmpty() - Method in class org.infinispan.util.ImmutableListCopy
 
isEmpty() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
isEnabled() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.  
isEnabled() - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
isEnabled() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
isEnabled() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
isEnabled() - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
isEnabled() - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
isEnabled() - Method in interface org.infinispan.config.FluentConfiguration.GroupsConfig
Deprecated.  
isEnabled() - Method in class org.infinispan.config.GroupsConfiguration
 
isEnabled() - Method in interface org.infinispan.eviction.EvictionManager
 
isEnabled() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
isEnabled() - Method in enum org.infinispan.eviction.EvictionStrategy
 
isEnabled() - Method in interface org.infinispan.eviction.PassivationManager
 
isEnabled() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
isEnabled() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isEnabled() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isEnabled() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
isEnabled() - Method in interface org.infinispan.remoting.ReplicationQueue
 
isEnabled() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
isEnableDeadlockDetection() - Method in class org.infinispan.config.Configuration
Deprecated. Use Configuration.isDeadlockDetectionEnabled() instead.
isEnableVersioning() - Method in class org.infinispan.config.Configuration
Deprecated. 
isEnlisted() - Method in class org.infinispan.transaction.LocalTransaction
 
isEnlisted() - Method in class org.infinispan.transaction.synchronization.SyncLocalTransaction
 
isEnlisted() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
As per the JTA spec, XAResource.start is called on enlistment.
isEvicted() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isEvicted() - Method in interface org.infinispan.container.entries.CacheEntry
 
isEvicted() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isEvicted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isExpirationReaperEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isExpired(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
isExpired(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
isExpired() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
isExpired(long) - Method in interface org.infinispan.container.entries.InternalCacheValue
 
isExpired() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.MortalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.TransientCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
isExposeGlobalJmxStatistics() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
isExposeJmxStatistics() - Method in class org.infinispan.config.Configuration
Deprecated.  
isFetchInMemoryState() - Method in class org.infinispan.config.Configuration
Deprecated.  
isFetchInMemoryState() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
isFetchPersistentState() - Method in class org.infinispan.config.CacheLoaderManagerConfig
Loops through all individual cache loader configs and checks if fetchPersistentState is set on any of them
isFetchPersistentState() - Method in class org.infinispan.config.Configuration
Deprecated.  
isFetchPersistentState() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isFetchPersistentState() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isFetchPersistentState() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isFetchPersistentState() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isFetchPersistentState() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
isFile() - Method in class org.infinispan.io.GridFile
 
isFile() - Method in class org.infinispan.io.GridFile.Metadata
 
isFirst() - Method in class org.infinispan.config.CustomInterceptorConfig
 
isFirst() - Method in class org.infinispan.query.impl.AbstractIterator
 
isFirst() - Method in interface org.infinispan.query.QueryIterator
 
isFirstInChain(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
 
isFlagSet(DeltaAwareCacheEntry.Flags) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
Tests whether a flag is set.
isFlagSet(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Tests whether a flag is set.
isFlagsUninitialized() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
isFramed() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
isGetMethod(Method) - Static method in class org.infinispan.util.ReflectionUtil
 
isGlobalScope() - Method in class org.infinispan.factories.components.ComponentMetadata
 
isGroupsEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isHashActivated() - Method in class org.infinispan.config.Configuration
Deprecated.  
isHeldExclusively() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
isIgnoreModifications() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isIgnoreModifications() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isIgnoreModifications() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
isImmutable(Object) - Static method in class org.infinispan.util.Immutables
Whether or not this collection type is immutable
isImplicitTransaction() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
isImplicitTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
 
isImplicitTransaction() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
isImplicitTransaction() - Method in class org.infinispan.transaction.LocalTransaction
 
isIndexingEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isIndexLocalOnly() - Method in class org.infinispan.config.Configuration
Deprecated.  
isIndexLocalOnly() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
isInDoubt() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
A transaction is in doubt if it is prepared and and it is orphan.
isInTxScope() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
isInTxScope() - Method in class org.infinispan.context.impl.ImmutableContext
 
isInTxScope() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
isInTxScope() - Method in interface org.infinispan.context.InvocationContext
Returns true if this call is performed in the context of an transaction, false otherwise.
isInTxScope() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
isInTxScope() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
isInvalidation() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated. Returns true if the mode is invalidation, either sync or async.
isInvalidation() - Method in enum org.infinispan.configuration.cache.CacheMode
Returns true if the mode is invalidation, either sync or async.
isInvocationBatchingEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isIs() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isIsMethod(Method) - Static method in class org.infinispan.util.ReflectionUtil
 
isJoinComplete() - Method in interface org.infinispan.distribution.DistributionManager
Tests whether the current instance has completed joining the cluster
isJoinComplete() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
isJoinComplete() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
isJoinComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
isKeyGeneratorThreadActive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isKeyGeneratorThreadAlive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isKeyLocalToAddress(Address, Object, int) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
isKeyLocalToAddress(Address, Object, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Test to see whether a key is mapped to a given address.
isKeyLocalToAddress(Address, Object, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
isKeyLocalToAddress(Address, Object, int) - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash
 
isKnownMarshallable(Class<?>) - Method in class org.infinispan.marshall.MarshallableTypeHints
Returns whether the hint on whether a particular type is marshallable or not is available.
isL1CacheActivated() - Method in class org.infinispan.config.Configuration
Deprecated.  
isL1CacheEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isL1OnRehash() - Method in class org.infinispan.config.Configuration
Deprecated.  
isLast() - Method in class org.infinispan.config.CustomInterceptorConfig
 
isLast() - Method in class org.infinispan.query.impl.AbstractIterator
 
isLast() - Method in interface org.infinispan.query.QueryIterator
 
isLastViewId(int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
isLazyPurgingOnly() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
isLocal() - Method in enum org.infinispan.distribution.DataLocality
 
isLocal(Object) - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.  
isLocal(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
Deprecated. 
isLocal() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
isLocal() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
Returns true if the transaction information is also present on this node.
isLocalModeForced(InvocationContext) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
isLocatedLocally(String) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
isLocationInDoubt(Object) - Method in class org.infinispan.statetransfer.DistributedStateTransferManagerImpl
 
isLocationInDoubt(Object) - Method in class org.infinispan.statetransfer.DummyInvalidationStateTransferManagerImpl
Deprecated.  
isLocationInDoubt(Object) - Method in class org.infinispan.statetransfer.ReplicatedStateTransferManagerImpl
 
isLocationInDoubt(Object) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
isLocked(LockManager, Fqn) - Static method in class org.infinispan.tree.TreeStructureSupport
 
isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Returns true if the cache entry is locked (either for reading or writing) by anyone, and false otherwise.
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
isLocked() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
isLockPlaceholder() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isLockPlaceholder() - Method in interface org.infinispan.container.entries.CacheEntry
 
isLockPlaceholder() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isLockPlaceholder() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isLockPlaceholder() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isManageable() - Method in class org.infinispan.factories.components.ComponentMetadata
 
isManageable() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
isManageConnectionFactory() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
If this method returns false, then the connection factory should not be created by the JdbcStringBasedCacheStore, but will be injected through JdbcStringBasedCacheStore.doConnectionFactoryInitialization(org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory)
isMarkedForRollback() - Method in class org.infinispan.transaction.LocalTransaction
 
isMarshallable(Object) - Method in class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
isMarshallable(Class<?>) - Method in class org.infinispan.marshall.MarshallableTypeHints
Returns whether a type can be serialized.
isMarshallable(Object) - Method in interface org.infinispan.marshall.Marshaller
A method that checks whether the given object is marshallable as per the rules of this marshaller.
isMarshallable(Object) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
isMarshallableCandidate(Object) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
isMarshallableCandidate(Object) - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
IsMarshallableInterceptor - Class in org.infinispan.interceptors
Interceptor to verify whether parameters passed into cache are marshallables or not.
IsMarshallableInterceptor() - Constructor for class org.infinispan.interceptors.IsMarshallableInterceptor
 
isMaster - Variable in class org.infinispan.demo.Demo
 
isMergeView() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
isMergeView() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
isMissingModifications() - Method in class org.infinispan.transaction.RemoteTransaction
 
isMulticastCapable() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
isMulticastCapable() - Method in interface org.infinispan.remoting.transport.Transport
Tests whether the transport supports true multicast
isNoNamespaceAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
isNonExistent() - Method in class org.infinispan.commands.write.RemoveCommand
 
isNull() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isNull() - Method in interface org.infinispan.container.entries.CacheEntry
Tests whether the entry represents a null value, typically used for repeatable read.
isNull() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isNull() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isNull() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isolationLevel - Variable in class org.infinispan.config.Configuration.LockingType
Deprecated.  
isolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
isolationLevel(IsolationLevel) - Method in interface org.infinispan.config.FluentConfiguration.LockingConfig
Deprecated. Cache isolation level.
isolationLevel() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Cache isolation level.
isolationLevel(IsolationLevel) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Cache isolation level.
IsolationLevel - Enum in org.infinispan.util.concurrent
Various transaction isolation levels as an enumerated class.
isOnePhaseCommit() - Method in class org.infinispan.commands.tx.PrepareCommand
 
isOnePhaseCommit() - Method in class org.infinispan.config.Configuration
Deprecated.  
isOnRehash() - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
isOpen() - Method in class org.infinispan.io.ReadableGridFileChannel
 
isOpen() - Method in class org.infinispan.io.WritableGridFileChannel
 
isOpened() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
isOriginLocal() - Method in class org.infinispan.context.impl.ImmutableContext
 
isOriginLocal() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
isOriginLocal() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
isOriginLocal() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
isOriginLocal() - Method in interface org.infinispan.context.InvocationContext
Returns true if the call was originated locally, false if it is the result of a remote rpc.
isOriginLocal() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
isOriginLocal() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
isOriginLocal() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
 
isOrphan() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
A remote transaction is orphan if the node on which the transaction originated (ie the originator) is no longer part of the cluster.
isParameterNameSet(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
isPassivation() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
ISPN_NS - Static variable in class org.infinispan.config.parsing.NamespaceFilter
 
ISPNEagerTopDocs - Class in org.infinispan.query.clustered
ISPNEagerTopDocs.
ISPNEagerTopDocs(TopDocs, Object[]) - Constructor for class org.infinispan.query.clustered.ISPNEagerTopDocs
 
isPre() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
isPre() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
isPreload() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
isPrepared() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
 
isPrepared() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
isPrepared() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryAwareTransaction
 
isPurgeOnStartup() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isPurgeOnStartup() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isPurgeOnStartup() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
isPurgeSynchronously() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
isPurgeSynchronously() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
isPurgeSynchronously() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
isPushStateWhenCoordinator() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
isPutIfAbsent() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isReadOnly() - Method in class org.infinispan.transaction.LocalTransaction
 
isRehashEnabled() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
isRehashEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isRehashInProgress() - Method in interface org.infinispan.distribution.DistributionManager
Tests whether a rehash is in progress
isRehashInProgress() - Method in class org.infinispan.distribution.DistributionManagerImpl
Tests whether a rehash is in progress
isRemote() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
isRemoved() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isRemoved() - Method in interface org.infinispan.container.entries.CacheEntry
 
isRemoved() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isRemoved() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isRemoved() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isReplayEntryWrapping() - Method in class org.infinispan.commands.tx.PrepareCommand
If set to true, then the keys touched by this transaction are to be wrapped again and original ones discarded.
isReplicated() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.  
isReplicated() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isReturnValueExpected() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.read.MapReduceCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.recovery.RecoveryCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.RemoveCacheCommand
 
isReturnValueExpected() - Method in interface org.infinispan.commands.ReplicableCommand
If true, a return value will be provided when performed remotely.
isReturnValueExpected() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.tx.PrepareCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.ClearCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.PutMapCommand
 
isReturnValueExpected() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
isRoot() - Method in class org.infinispan.tree.Fqn
Returns true if this is a root Fqn.
isRunning() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
isRunning(String) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
isRunning(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
isRunning(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Tests whether a named cache is running.
isSameMachine(TopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
isSameMachine(TopologyAwareAddress) - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
isSameRack(TopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
isSameRack(TopologyAwareAddress) - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
isSameRM(XAResource) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
the only situation in which it returns true is when the other xa resource pertains to the same cache, on the same node.
isSameSite(TopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
isSameSite(TopologyAwareAddress) - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
isSecondPhaseAsync() - Method in class org.infinispan.config.Configuration
Deprecated. Returns true if the 2nd phase of the 2PC (i.e.
isSecure() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
isSetMethod(Method) - Static method in class org.infinispan.util.ReflectionUtil
 
isShared() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
isShared() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isShared() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isSharedKeyspace() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
isShutdown - Variable in class org.infinispan.distexec.DefaultExecutorService
 
isShutdown() - Method in class org.infinispan.distexec.DefaultExecutorService
 
isShutdown() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
isShutdown() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
isShutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isSingleton() - Method in class org.infinispan.spring.provider.ContainerCacheManagerFactoryBean
 
isSingleton() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
Always returns true.
isSingleton() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
Always return true.
isSingleton() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
Always returns true.
isSingleton() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
Always returns true.
isSingleton() - Method in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
Always returns true.
isSingleton() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
Always return true.
isSingleton() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
Always return true.
isSingletonStoreEnabled() - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
isStarted() - Method in interface org.infinispan.affinity.KeyAffinityService
Checks weather or not the service is started.
isStarted() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isStarted() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
isStateTransferEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.  
isStateTransferInProgress() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
isStatisticsEnabled() - Method in class org.infinispan.interceptors.TxInterceptor
 
isStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
isStopping() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
isStoreAsBinary() - Method in class org.infinispan.config.Configuration
Deprecated.  
isStoreKeysAsBinary() - Method in class org.infinispan.config.Configuration
Deprecated.  
isStoreKeysAsBinary() - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
isStoreValuesAsBinary() - Method in class org.infinispan.config.Configuration
Deprecated.  
isStoreValuesAsBinary() - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
isStrictPeerToPeer() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.  
isSuccessful() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.ClearCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.PutMapCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.RemoveCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.ReplaceCommand
 
isSuccessful() - Method in interface org.infinispan.commands.write.WriteCommand
Some commands may want to provide information on whether the command was successful or not.
isSuccessful() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
isSuccessful() - Method in interface org.infinispan.remoting.responses.Response
 
isSuccessful() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
isSuccessful() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
isSuccessful() - Method in class org.infinispan.remoting.responses.UnsureResponse
 
isSupported(OptionalFeature) - Method in class org.infinispan.cdi.InfinispanAnnotationProvider
 
isSupportedType(Class<?>) - Method in class org.infinispan.loaders.keymappers.DefaultTwoWayKey2StringMapper
 
isSupportedType(Class<?>) - Method in interface org.infinispan.loaders.keymappers.Key2StringMapper
Do we support this key type?
isSupportedType(Class<?>) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
 
isSurvivesRestarts() - Method in class org.infinispan.factories.components.ComponentMetadata
 
isSuspendTxAfterInvocation() - Method in class org.infinispan.batch.BatchContainer
 
isSyncCommitPhase() - Method in class org.infinispan.config.Configuration
Deprecated. Important - to be used with caution: if you have two transactions writing to the same key concurrently and the commit is configured to be performed asynchronously then inconsistencies might happen.
isSyncCommitPhase() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
isSynchronous() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.  
isSynchronous() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
isSynchronous() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isSynchronous(InvocationContext) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
isSynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isSyncRollbackPhase() - Method in class org.infinispan.config.Configuration
Deprecated.  
isSyncRollbackPhase() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
isTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
isTcpNoDelay() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
isTerminated() - Method in class org.infinispan.distexec.DefaultExecutorService
 
isTerminated() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
isTerminated() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
isTerminated() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
isTerminated() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isTransactionalCache() - Method in class org.infinispan.config.Configuration
Deprecated. Returns true if the cache is configured to run in transactional mode, false otherwise.
isTransactionAutoCommit() - Method in class org.infinispan.config.Configuration
Deprecated. If the cache is transactional (i.e.
isTransactionInProgress() - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Returns a boolean value whether or not a transaction is in progress (JTA transaction and in this case *not* an org.hibernate transaction).
isTransactionManagerExpected() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
isTransactionPrepared(GlobalTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Checks both internal state and transaction table's state for the given tx.
isTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
isTransactionRecoveryEnabled() - Method in class org.infinispan.config.Configuration
Deprecated. Returns true if transaction recovery information is collected.
isTransactionSuccessful() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
isTransactionSuccessful() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionCompletedEvent
 
isTransactionValid() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
isTransactionValid() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
isTransactionValid() - Method in interface org.infinispan.context.impl.TxInvocationContext
 
isTransactionValid() - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
isTypeExcluded(Class<?>) - Static method in class org.infinispan.marshall.MarshalledValue
Tests whether the type should be excluded from MarshalledValue wrapping.
isUncertain() - Method in enum org.infinispan.distribution.DataLocality
 
isUnlock() - Method in class org.infinispan.commands.control.LockControlCommand
 
isUnreliableReturnValues() - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
isUnsafeUnreliableReturnValues() - Method in class org.infinispan.config.Configuration
Deprecated.  
isUpdated() - Method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
 
isUse1PcForAutoCommitTransactions() - Method in class org.infinispan.config.Configuration
Deprecated. Enabling this would cause autoCommit transactions (Configuration.isTransactionAutoCommit()) to complete with 1 RPC instead of 2 RPCs (which is default).
isUseAsyncMarshalling() - Method in class org.infinispan.config.Configuration
Deprecated.  
isUseDefaultRemoteCache() - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
isUseEagerLocking() - Method in class org.infinispan.config.Configuration
Deprecated. 
isUseEagerLocking() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
isUseFutureReturnType() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
isUseFutureReturnType() - Method in class org.infinispan.context.impl.ImmutableContext
 
isUseFutureReturnType() - Method in interface org.infinispan.context.InvocationContext
Indicates whether the call requires a Future as return type.
isUseFutureReturnType() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
isUseLazyDeserialization() - Method in class org.infinispan.config.Configuration
Deprecated. Use Configuration.isStoreAsBinary()
isUseLockStriping() - Method in class org.infinispan.config.Configuration
Deprecated.  
isUseLockStriping() - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
isUseReplQueue() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
isUseReplQueue() - Method in class org.infinispan.config.Configuration
Deprecated.  
isUseSetter() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isUseSynchronization() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
isUseSynchronizationForTransactions() - Method in class org.infinispan.config.Configuration
Deprecated. If enabled Infinispan enlists within transactions as a Synchronization.
isUseXaXid() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
isUsingCacheLoaders() - Method in class org.infinispan.config.Configuration
Deprecated.  
isUsingPassivation() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isUsingPassivation() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isUsingPreload() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
isValid() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
isValid() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isValid() - Method in interface org.infinispan.container.entries.CacheEntry
 
isValid() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isValid() - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
isValid() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isValid() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
isValid() - Method in interface org.infinispan.remoting.responses.Response
 
isValid() - Method in class org.infinispan.remoting.responses.ValidResponse
 
isValid(String) - Method in class org.infinispan.tools.doclet.html.HtmlGenerator
 
isValid() - Method in interface org.infinispan.tree.Node
Tests if a node reference is still valid.
isValid() - Method in class org.infinispan.tree.NodeImpl
 
isVariableLimitSupported() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
isViewInstallationInProgress() - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
 
isVirtualNodesEnabled() - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
isWritable() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isWriteSkewCheck() - Method in class org.infinispan.config.Configuration
Deprecated.  
isWriteSkewCheck() - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
iterator() - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
iterator() - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
iterator() - Method in class org.infinispan.container.DefaultDataContainer
 
iterator(int) - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a QueryIterator with a given integer parameter - the fetchSize.
iterator() - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a QueryIterator.
iterator(int) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
iterator() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
iterator(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
iterator() - Method in class org.infinispan.tools.schema.TreeNode
 
iterator() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
iterator() - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
iterator() - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
iterator() - Method in class org.infinispan.util.FastCopyHashMap.Values
 
iterator() - Method in class org.infinispan.util.ForwardingList
 
iterator() - Method in class org.infinispan.util.ImmutableListCopy
 
iterator() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 

J

JavaLog - Interface in org.infinispan.rest.logging
Log abstraction for the REST server module.
JavaLog - Interface in org.infinispan.server.core.logging
Log abstraction for the server core module.
JavaLog - Interface in org.infinispan.server.hotrod.logging
Log abstraction for the Hot Rod server module.
JavaLog - Interface in org.infinispan.server.memcached.logging
Log abstraction for the Memcached server module.
JAXBUnmarshallable - Interface in org.infinispan.config
A mechanism to notify an XML element that the JAXB parser has willUnmarshall it
JBossExternalizerAdapter - Class in org.infinispan.marshall.jboss
 
JBossExternalizerAdapter(Externalizer<?>) - Constructor for class org.infinispan.marshall.jboss.JBossExternalizerAdapter
 
JBossMarshaller - Class in org.infinispan.marshall.jboss
A JBoss Marshalling based marshaller that is oriented at internal, embedded, Infinispan usage.
JBossMarshaller() - Constructor for class org.infinispan.marshall.jboss.JBossMarshaller
 
JBossMarshaller.EmbeddedContextClassResolver - Class in org.infinispan.marshall.jboss
An embedded context class resolver that is able to retrieve a class loader from the embedded Infinispan call context.
JBossMarshaller.EmbeddedContextClassResolver(ClassLoader, InvocationContextContainer) - Constructor for class org.infinispan.marshall.jboss.JBossMarshaller.EmbeddedContextClassResolver
 
JBossMarshallerFactory - Class in org.infinispan.marshall.jboss
A JBoss Marshalling factory class for retrieving marshaller/unmarshaller instances.
JBossMarshallerFactory() - Constructor for class org.infinispan.marshall.jboss.JBossMarshallerFactory
 
JBossMBeanServerLookup - Class in org.infinispan.jmx
MBeanServer lookup implementation to locate the JBoss MBeanServer.
JBossMBeanServerLookup() - Constructor for class org.infinispan.jmx.JBossMBeanServerLookup
 
JBossStandaloneJTAManagerLookup - Class in org.infinispan.transaction.lookup
JTA standalone TM lookup.
JBossStandaloneJTAManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
JBossTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Uses JNDI to look-up the TransactionManager instance from "java:/TransactionManager".
JBossTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossTransactionManagerLookup
 
JdbcBinaryCacheStore - Class in org.infinispan.loaders.jdbc.binary
BucketBasedCacheStore implementation that will store all the buckets as rows in database, each row corresponding to a bucket.
JdbcBinaryCacheStore() - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
JdbcBinaryCacheStoreConfig - Class in org.infinispan.loaders.jdbc.binary
Defines available configuration elements for JdbcBinaryCacheStore.
JdbcBinaryCacheStoreConfig(boolean) - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcBinaryCacheStoreConfig(ConnectionFactoryConfig, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcBinaryCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
 
JdbcMixedCacheStore - Class in org.infinispan.loaders.jdbc.mixed
Cache store that combines functionality of JdbcBinaryCacheStore and JdbcStringBasedCacheStore.
JdbcMixedCacheStore() - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
JdbcMixedCacheStoreConfig - Class in org.infinispan.loaders.jdbc.mixed
Configuration for JdbcMixedCacheStore.
JdbcMixedCacheStoreConfig(ConnectionFactoryConfig, TableManipulation, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
JdbcMixedCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
JdbcStringBasedCacheStore - Class in org.infinispan.loaders.jdbc.stringbased
CacheStore implementation that stores the entries in a database.
JdbcStringBasedCacheStore() - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
JdbcStringBasedCacheStoreConfig - Class in org.infinispan.loaders.jdbc.stringbased
Configuration for JdbcStringBasedCacheStore cache store.
JdbcStringBasedCacheStoreConfig(ConnectionFactoryConfig, TableManipulation) - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcStringBasedCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcStringBasedCacheStoreConfig(boolean) - Constructor for class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
JdbcUtil - Class in org.infinispan.loaders.jdbc
Contains common methods used by JDBC CacheStores.
JdbcUtil() - Constructor for class org.infinispan.loaders.jdbc.JdbcUtil
 
JdbmCacheStore - Class in org.infinispan.loaders.jdbm
A persistent CacheLoader based on the JDBM project.
JdbmCacheStore() - Constructor for class org.infinispan.loaders.jdbm.JdbmCacheStore
 
JdbmCacheStoreConfig - Class in org.infinispan.loaders.jdbm
Configures JdbmCacheStore.
JdbmCacheStoreConfig() - Constructor for class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
jdbmDbOpened(File) - Method in interface org.infinispan.loaders.jdbm.logging.Log
 
JdbmSerializer - Class in org.infinispan.loaders.jdbm
Uses the configured (runtime) StreamingMarshaller of the cache.
JdbmSerializer(StreamingMarshaller) - Constructor for class org.infinispan.loaders.jdbm.JdbmSerializer
Constructs a new JdbmSerializer.
JDK_SETS - Static variable in interface org.infinispan.marshall.Ids
 
JGROUPS_ADDRESS - Static variable in interface org.infinispan.marshall.Ids
 
JGROUPS_TOPOLOGY_AWARE_ADDRESS - Static variable in interface org.infinispan.marshall.Ids
 
JGroupsAddress - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups Address
JGroupsAddress(Address) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
JGroupsAddress.Externalizer - Class in org.infinispan.remoting.transport.jgroups
 
JGroupsAddress.Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
JGroupsChannelLookup - Interface in org.infinispan.remoting.transport.jgroups
A hook to pass in a JGroups channel.
JGroupsResponseFilterAdapter - Class in org.infinispan.remoting.transport.jgroups
Acts as a bridge between JGroups RspFilter and ResponseFilter.
JGroupsResponseFilterAdapter(ResponseFilter) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
Creates an instance of the adapter
JGroupsTopologyAwareAddress - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups Address
JGroupsTopologyAwareAddress(TopologyUUID) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
JGroupsTopologyAwareAddress.Externalizer - Class in org.infinispan.remoting.transport.jgroups
 
JGroupsTopologyAwareAddress.Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
JGroupsTransport - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups transport.
JGroupsTransport(Channel) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
This form is used when the transport is created by an external source and passed in to the GlobalConfiguration.
JGroupsTransport() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
JmxAttributeMetadata - Class in org.infinispan.factories.components
Persistable and cacheable metadata for JMX attributes
JmxAttributeMetadata(Field) - Constructor for class org.infinispan.factories.components.JmxAttributeMetadata
 
JmxAttributeMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxAttributeMetadata
 
JmxComponent - Class in org.infinispan.tools.doclet.jmx
A JMX Component
JmxComponent() - Constructor for class org.infinispan.tools.doclet.jmx.JmxComponent
 
JmxDoclet - Class in org.infinispan.tools.doclet.jmx
A Doclet that generates a guide to all JMX components exposed by Infinispan
JmxDoclet() - Constructor for class org.infinispan.tools.doclet.jmx.JmxDoclet
 
jmxDomain(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated. If JMX statistics are enabled then all 'published' JMX objects will appear under this name.
jmxDomain - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
jmxDomain(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
jmxDomain(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
If JMX statistics are enabled then all 'published' JMX objects will appear under this name.
JmxDomainConflictException - Exception in org.infinispan.jmx
 
JmxDomainConflictException(String) - Constructor for exception org.infinispan.jmx.JmxDomainConflictException
 
JmxHtmlGenerator - Class in org.infinispan.tools.doclet.jmx
 
JmxHtmlGenerator(String, String, String, String, String, String, List<String>, List<MBeanComponent>) - Constructor for class org.infinispan.tools.doclet.jmx.JmxHtmlGenerator
 
JmxOperationMetadata - Class in org.infinispan.factories.components
Persistable and cacheable metadata for JMX operations
JmxOperationMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxOperationMetadata
 
jmxStatistics() - Method in class org.infinispan.configuration.cache.Configuration
 
jmxStatistics() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
jmxStatistics() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
JMXStatisticsConfiguration - Class in org.infinispan.configuration.cache
Determines whether statistics are gather and reported.
JMXStatisticsConfigurationBuilder - Class in org.infinispan.configuration.cache
Determines whether statistics are gather and reported.
JmxStatisticsExposer - Interface in org.infinispan.jmx
Interface containing common cache management operations
JmxStatsCommandInterceptor - Class in org.infinispan.interceptors.base
Base class for all the interceptors exposing management statistics.
JmxStatsCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
JmxUtil - Class in org.infinispan.jmx
Class containing JMX related utility methods.
JmxUtil() - Constructor for class org.infinispan.jmx.JmxUtil
 
join(String, CacheViewListener) - Method in interface org.infinispan.cacheviews.CacheViewsManager
Start the cache.
join(String, CacheViewListener) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
joinEvent(Address) - Method in interface org.infinispan.util.logging.Log
 
joinRehashAborted(Address, String) - Method in interface org.infinispan.util.logging.Log
 
joinRehashCompleted(Address, String) - Method in interface org.infinispan.util.logging.Log
 
jumpToResult(int) - Method in class org.infinispan.query.clustered.DistributedIterator
 
jumpToResult(int) - Method in class org.infinispan.query.impl.EagerIterator
Jumps to a given index in the list of results.
jumpToResult(int) - Method in class org.infinispan.query.impl.LazyIterator
 
jumpToResult(int) - Method in interface org.infinispan.query.QueryIterator
Jumps to a specific index in the iterator.

K

key - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
key - Variable in class org.infinispan.commands.read.AbstractDataCommand
 
key - Variable in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
key - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
key - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
KEY - Static variable in interface org.infinispan.server.websocket.OpHandler
 
Key2StringMapper - Interface in org.infinispan.loaders.keymappers
Defines the logic of mapping a key object to a String.
KEY_DOES_NOT_EXIST_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
KEY_SIZE_ESTIMATE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
keyAffected() - Method in class org.infinispan.atomic.ClearOperation
 
keyAffected() - Method in class org.infinispan.atomic.Operation
 
keyAffected() - Method in class org.infinispan.atomic.PutOperation
 
keyAffected() - Method in class org.infinispan.atomic.RemoveOperation
 
KeyAffinityService<K> - Interface in org.infinispan.affinity
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
KeyAffinityServiceFactory - Class in org.infinispan.affinity
Factory for KeyAffinityService.
KeyAffinityServiceFactory() - Constructor for class org.infinispan.affinity.KeyAffinityServiceFactory
 
KeyAffinityServiceImpl<K> - Class in org.infinispan.affinity
Implementation of KeyAffinityService.
KeyAffinityServiceImpl(Executor, Cache<? extends K, ?>, KeyGenerator<? extends K>, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.KeyAffinityServiceImpl
 
keyClassNotFound(String, Exception) - Method in interface org.infinispan.query.logging.Log
 
keyDoesNotMapToLocalNode(Object, Collection<Address>) - Method in interface org.infinispan.util.logging.Log
 
KeyGenerator<K> - Interface in org.infinispan.affinity
Used for generating keys; used by KeyAffinityService to generate the affinity keys.
keyRead(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
keyRead(Object) - Method in class org.infinispan.transaction.LocalTransaction
 
keyRead(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
keys - Variable in class org.infinispan.commands.read.MapReduceCommand
 
keys - Variable in class org.infinispan.commands.write.InvalidateCommand
 
keys - Variable in class org.infinispan.query.clustered.ISPNEagerTopDocs
 
keys() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns an enumeration of the keys in this table.
keySet() - Method in class org.infinispan.AbstractDelegatingCache
 
keySet() - Method in class org.infinispan.atomic.AtomicHashMap
 
keySet() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
keySet() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
keySet() - Method in interface org.infinispan.Cache
Returns a set view of the keys contained in this cache.
keySet() - Method in class org.infinispan.CacheImpl
 
keySet() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
keySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
keySet() - Method in interface org.infinispan.container.DataContainer
Returns a set of keys in the container.
keySet() - Method in class org.infinispan.container.DefaultDataContainer
 
keySet() - Method in class org.infinispan.DecoratedCache
 
keySet - Variable in class org.infinispan.util.AbstractMap
 
keySet() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.infinispan.util.FastCopyHashMap
 
KeySetCommand - Class in org.infinispan.commands.read
Command implementation for Map.keySet() functionality.
KeySetCommand(DataContainer) - Constructor for class org.infinispan.commands.read.KeySetCommand
 
KeySetCommand.ExpiredFilteredKeySet - Class in org.infinispan.commands.read
 
KeySetCommand.ExpiredFilteredKeySet(Set<Object>, DataContainer) - Constructor for class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
keyToString(Object) - Method in class org.infinispan.query.backend.KeyTransformationHandler
 
KeyTransformationHandler - Class in org.infinispan.query.backend
This transforms arbitrary keys to a String which can be used by Lucene as a document identifier, and vice versa.
KeyTransformationHandler() - Constructor for class org.infinispan.query.backend.KeyTransformationHandler
 
keyTransformationHandler - Variable in class org.infinispan.query.impl.CacheQueryImpl
 
kill(UUID) - Method in class org.infinispan.query.clustered.QueryBox
Kill the query (DocumentExtractor)
KnownComponentNames - Class in org.infinispan.factories
Holder for known named component names.
KnownComponentNames() - Constructor for class org.infinispan.factories.KnownComponentNames
 

L

l1 - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
l1() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
l1() - Method in interface org.infinispan.config.FluentConfiguration.ClusteringConfig
Deprecated. This method allows configuration of the L1 cache for distributed caches.
l1() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
This method allows configuration of the L1 cache for distributed caches.
l1() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
This method allows configuration of the L1 cache for distributed caches.
l1() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
Configures the L1 cache behavior in 'distributed' caches instances.
L1Configuration - Class in org.infinispan.configuration.cache
Configures the L1 cache behavior in 'distributed' caches instances.
L1ConfigurationBuilder - Class in org.infinispan.configuration.cache
Configures the L1 cache behavior in 'distributed' caches instances.
L1Manager - Interface in org.infinispan.distribution
Manages the L1 Cache, in particular recording anyone who is going to cache an a command that a node responds to so that a unicast invalidation can be sent later if needed.
L1ManagerImpl - Class in org.infinispan.distribution
 
L1ManagerImpl() - Constructor for class org.infinispan.distribution.L1ManagerImpl
 
last() - Method in class org.infinispan.config.Configuration.CustomInterceptorPositionType
Deprecated.  
last() - Method in interface org.infinispan.config.FluentConfiguration.CustomInterceptorPosition
Deprecated.  
last() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
last() - Method in class org.infinispan.query.impl.AbstractIterator
 
last() - Method in interface org.infinispan.query.QueryIterator
Jumps to the last result
lastAsyncProcessorShutsDownExecutor - Variable in class org.infinispan.loaders.decorators.AsyncStore
 
lastIndexOf(Object) - Method in class org.infinispan.util.ForwardingList
 
lastIndexOf(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
lastModified() - Method in class org.infinispan.io.GridFile
 
lastModified - Variable in class org.infinispan.remoting.MIMECacheEntry
The date the entry was created...
lastUsed - Variable in class org.infinispan.container.entries.TransientCacheValue
 
lastUsed - Variable in class org.infinispan.container.entries.TransientMortalCacheValue
 
lazyDeserializationDeprecated() - Method in interface org.infinispan.util.logging.Log
 
LazyInitializingExecutorService - Class in org.infinispan.executors
A delegating executor that lazily constructs and initializes the underlying executor, since unused JDK executors are expensive.
LazyInitializingExecutorService(ExecutorFactory, Properties) - Constructor for class org.infinispan.executors.LazyInitializingExecutorService
 
LazyInitializingScheduledExecutorService - Class in org.infinispan.executors
A delegating scheduled executor that lazily constructs and initalizes the underlying scheduled executor, since unused JDK executors are expensive.
LazyInitializingScheduledExecutorService(ScheduledExecutorFactory, Properties) - Constructor for class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
lazyIterator(int) - Method in interface org.infinispan.query.CacheQuery
Lazily loads the results from the Query as a QueryIterator with a given integer parameter - the fetchSize.
lazyIterator() - Method in interface org.infinispan.query.CacheQuery
Calls the CacheQuery.lazyIterator(int fetchSize) method but passes in a default 1 as a parameter.
lazyIterator(int) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
lazyIterator() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
lazyIterator(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
LazyIterator - Class in org.infinispan.query.impl
Implementation for QueryIterator.
LazyIterator(HSQuery, AdvancedCache<?, ?>, KeyTransformationHandler, int) - Constructor for class org.infinispan.query.impl.LazyIterator
 
lazyQueryId - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
leave(String) - Method in interface org.infinispan.cacheviews.CacheViewsManager
Stop the cache.
leave(String) - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
leaveEvent(Address) - Method in interface org.infinispan.util.logging.Log
 
LegacyConfigurationAdaptor - Class in org.infinispan.configuration.cache
 
LegacyGlobalConfigurationAdaptor - Class in org.infinispan.configuration.global
 
LegacyKeySupportSystemProperties - Class in org.infinispan.util
A wrapper around system properties that supports legacy keys
LegacyKeySupportSystemProperties() - Constructor for class org.infinispan.util.LegacyKeySupportSystemProperties
 
LegacyKeySupportTypedProperties - Class in org.infinispan.util
An extension of TypedProperties that has support for legacy keys.
LegacyKeySupportTypedProperties(Properties, Map<String, String>) - Constructor for class org.infinispan.util.LegacyKeySupportTypedProperties
 
LegacyKeySupportTypedProperties(Map<String, String>) - Constructor for class org.infinispan.util.LegacyKeySupportTypedProperties
 
length() - Method in class org.infinispan.io.GridFile
 
length() - Method in class org.infinispan.lucene.InfinispanIndexInput
 
length() - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
length() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
levelOrderTraverse(TreeNode) - Method in class org.infinispan.tools.schema.AbstractTreeWalker
 
Lifecycle - Interface in org.infinispan.lifecycle
Lifecycle interface that defines the lifecycle of components
LifecycleCallbacks - Class in org.infinispan.lucene
Module lifecycle callbacks implementation that enables module specific AdvancedExternalizer implementations to be registered.
LifecycleCallbacks() - Constructor for class org.infinispan.lucene.LifecycleCallbacks
 
LifecycleCallbacks - Class in org.infinispan.tree
Module lifecycle callbacks implementation that enables module specific AdvancedExternalizer implementations to be registered.
LifecycleCallbacks() - Constructor for class org.infinispan.tree.LifecycleCallbacks
 
LifecycleManager - Class in org.infinispan.query.impl
Lifecycle of the Query module: initializes the Hibernate Search engine and shuts it down at cache stop.
LifecycleManager() - Constructor for class org.infinispan.query.impl.LifecycleManager
 
lifespan - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
lifespan - Variable in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
lifespan(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
lifespan - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.  
lifespan(Long) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
lifespan(Long) - Method in interface org.infinispan.config.FluentConfiguration.ExpirationConfig
Deprecated. Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds.
lifespan(Long) - Method in interface org.infinispan.config.FluentConfiguration.L1Config
Deprecated. Maximum lifespan of an entry placed in the L1 cache.
lifespan() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds.
lifespan(long) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds.
lifespan() - Method in class org.infinispan.configuration.cache.L1Configuration
Maximum lifespan of an entry placed in the L1 cache.
lifespan(long) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Maximum lifespan of an entry placed in the L1 cache.
lifespan - Variable in class org.infinispan.container.entries.MortalCacheValue
 
LINKED_LIST - Static variable in interface org.infinispan.marshall.Ids
 
LinkedListExternalizer - Class in org.infinispan.marshall.exts
LinkedListExternalizer.
LinkedListExternalizer() - Constructor for class org.infinispan.marshall.exts.LinkedListExternalizer
 
list() - Method in class org.infinispan.io.GridFile
 
list(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
list() - Method in class org.infinispan.lucene.InfinispanDirectory
list() - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a list.
list() - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
list() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
listAll() - Method in class org.infinispan.lucene.InfinispanDirectory
new name for list() in Lucene 3.0
listAllDocuments() - Method in class org.infinispan.lucenedemo.DemoActions
Returns a list of the values of all stored fields
listAllMembers() - Method in class org.infinispan.lucenedemo.DemoActions
Returns a list of Addresses of all members in the cluster
Listenable - Interface in org.infinispan.notifications
Interface that denotes that the implementation can have listeners attached to it.
listener - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
 
Listener - Annotation Type in org.infinispan.notifications
Class-level annotation used to annotate an object as being a valid cache listener.
ListenerRegistration - Class in org.infinispan.affinity
Used for registering various cache notifications.
ListenerRegistration(KeyAffinityServiceImpl<?>) - Constructor for class org.infinispan.affinity.ListenerRegistration
 
listenersMap - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
listFiles() - Method in class org.infinispan.io.GridFile
 
listFiles(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
listFiles(FileFilter) - Method in class org.infinispan.io.GridFile
 
listIterator() - Method in class org.infinispan.util.ForwardingList
 
listIterator(int) - Method in class org.infinispan.util.ForwardingList
 
listIterator() - Method in class org.infinispan.util.ImmutableListCopy
 
listIterator(int) - Method in class org.infinispan.util.ImmutableListCopy
 
listStoredValuesMatchingQuery(Query) - Method in class org.infinispan.lucenedemo.DemoActions
Runs a Query and returns the stored field for each matching document
load(Object) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Loads an entry mapped to by a given key.
load(int) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
 
load(Object) - Method in interface org.infinispan.loaders.CacheLoader
Loads an entry mapped to by a given key.
load(int) - Method in interface org.infinispan.loaders.CacheLoader
Loads up to a specific number of entries.
load(Object) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
load(int) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
load(Object) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(int) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(int) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
load(int) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
load(Object) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
load(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
load(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
load(int) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
load(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
load(int) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
load(Object) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
load(int) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
load(EntityInfo) - Method in class org.infinispan.query.impl.EntityLoader
 
load(EntityInfo...) - Method in class org.infinispan.query.impl.EntityLoader
 
loadAll() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Loads all entries in the loader.
loadAll() - Method in interface org.infinispan.loaders.CacheLoader
Loads all entries in the loader.
loadAll() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
loadAll() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAll() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAll() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAll() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
loadAll() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
loadAll() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAll() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
 
loadAllKeys(Set<Object>) - Method in interface org.infinispan.loaders.CacheLoader
Loads a set of all keys, excluding a filter set.
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllKeysProcess(ResultSet, Set<Object>, Set<Object>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllKeysSupport(Set<Object>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllLockSafe() - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllProcess(ResultSet, Set<InternalCacheEntry>) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllProcess(ResultSet, Set<InternalCacheEntry>, int) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadAllSupport(boolean) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
loadBucket(Integer) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Loads a Bucket from the store, based on the hash code of the bucket.
loadBucket(Integer) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
loadBucket(Integer) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadBucket(File) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadBucket(Integer) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadBucketContainingKey(String) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loadClass(String, ClassLoader) - Static method in class org.infinispan.util.Util
Loads the specified class using the passed classloader, or, if it is null the Infinispan classes' classloader.
loadClassStrict(String, ClassLoader) - Static method in class org.infinispan.util.Util
Loads the specified class using the passed classloader, or, if it is null the Infinispan classes' classloader.
loader - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
LoaderConfiguration - Class in org.infinispan.configuration.cache
Configuration a specific cache loader or cache store
LoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration a specific cache loader or cache store
LoaderConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
loaders() - Method in class org.infinispan.configuration.cache.Configuration
 
loaders() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
loaders() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
loaders() - Method in interface org.infinispan.configuration.cache.LoadersConfigurationChildBuilder
 
LoadersConfiguration - Class in org.infinispan.configuration.cache
Configuration for cache loaders and stores.
LoadersConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration for cache loaders and stores.
LoadersConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
LoadersConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
loadLockSafe(Object, Integer) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Loads an entry from a Bucket, locating the relevant Bucket using the key's hash code.
loadLockSafe(int) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadLockSafe(int) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
loadLockSafe(int) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadLockSafe(Object, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
loadLockSafe(int) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadLockSafe(Object, L) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadModuleCommandHandlers(ClassLoader) - Method in class org.infinispan.util.ModuleProperties
 
loadSome(int) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
localAddress - Variable in class org.infinispan.commands.read.MapReduceCommand
 
localAndPhysicalAddress(Address, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
LocalCommand - Interface in org.infinispan.commands
This is a marker interface to indicate that such commands will never be replicated and hence will not return any valid command IDs.
localExecutionFailed(Throwable) - Method in interface org.infinispan.util.logging.Log
 
localExecutorService - Variable in class org.infinispan.distexec.DefaultExecutorService
 
localLockIntention - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
LocalLockMergingSegmentReadLocker - Class in org.infinispan.lucene.readlocks
LocalLockMergingSegmentReadLocker decorates the DistributedSegmentReadLocker to minimize remote operations in case several IndexReaders are opened on the same InfinispanDirectory.
LocalLockMergingSegmentReadLocker(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Create a new LocalLockMergingSegmentReadLocker for specified cache and index name.
LocalLockMergingSegmentReadLocker(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Create a new LocalLockMergingSegmentReadLocker with special purpose caches
localModeWriteSkewCheck - Variable in class org.infinispan.container.EntryFactoryImpl
 
localNodeIsOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
localNodeIsOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
localNodeIsOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
localNodeIsPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AllNodesLogic
 
localNodeIsPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
localNodeIsPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
LocalQueryInterceptor - Class in org.infinispan.query.backend

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

LocalQueryInterceptor(SearchFactoryIntegrator) - Constructor for class org.infinispan.query.backend.LocalQueryInterceptor
 
LocalTransaction - Class in org.infinispan.transaction
Object that holds transaction's state on the node where it originated; as opposed to RemoteTransaction.
LocalTransaction(Transaction, GlobalTransaction, boolean, int) - Constructor for class org.infinispan.transaction.LocalTransaction
 
localTransactionPrepared(LocalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
localTransactionPrepared(LocalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
LocalTxInvocationContext - Class in org.infinispan.context.impl
Invocation context to be used for locally originated transactions.
LocalTxInvocationContext() - Constructor for class org.infinispan.context.impl.LocalTxInvocationContext
 
LocalXaTransaction - Class in org.infinispan.transaction.xa
LocalTransaction implementation to be used with TransactionXaAdapter.
LocalXaTransaction(Transaction, GlobalTransaction, boolean, int) - Constructor for class org.infinispan.transaction.xa.LocalXaTransaction
 
locate(Object, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Locates a key, given a replication count (number of copies).
locate(Object, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
locate(Object, int) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
locate(Object, int) - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash
 
locate(Object, int) - Method in class org.infinispan.distribution.ch.UnionConsistentHash
 
locate(Object) - Method in interface org.infinispan.distribution.DistributionManager
Locates a key in a cluster.
locate(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateAll(Collection<Object>, int) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
locateAll(Collection<Object>, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
The logical equivalent of calling ConsistentHash.locate(Object, int) multiple times for each key in the collection of keys.
locateAll(Collection<Object>) - Method in interface org.infinispan.distribution.DistributionManager
Locates a list of keys in a cluster.
locateAll(Collection<Object>, int) - Method in interface org.infinispan.distribution.DistributionManager
Same as DistributionManager.locateAll(java.util.Collection), but the list of addresses only contains numOwners owners.
locateAll(Collection<Object>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateAll(Collection<Object>, int) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateKey(String) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
location() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
location(String) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
location(String) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
lock(K...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
lock(K...) - Method in interface org.infinispan.AdvancedCache
Locks a given key or keys eagerly across cache nodes in a cluster.
lock(Collection<? extends K>) - Method in interface org.infinispan.AdvancedCache
Locks collections of keys eagerly across cache nodes in a cluster.
lock(K...) - Method in class org.infinispan.CacheImpl
 
lock(Collection<? extends K>) - Method in class org.infinispan.CacheImpl
 
lock(K...) - Method in class org.infinispan.DecoratedCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.DecoratedCache
 
lock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
lock(GlobalTransaction) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
LOCK_INFO - Static variable in interface org.infinispan.marshall.Ids
 
lockAcquisitionTimeout - Variable in class org.infinispan.config.Configuration.LockingType
Deprecated.  
lockAcquisitionTimeout(Long) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
lockAcquisitionTimeout(Long) - Method in interface org.infinispan.config.FluentConfiguration.LockingConfig
Deprecated. Maximum time to attempt a particular lock acquisition
lockAcquisitionTimeout() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Maximum time to attempt a particular lock acquisition
lockAcquisitionTimeout(long) - Method in class org.infinispan.configuration.cache.LockingConfiguration
 
lockAcquisitionTimeout(long) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Maximum time to attempt a particular lock acquisition
lockAcquistionTimeout() - Method in class org.infinispan.configuration.cache.AbstractLockSupportCacheStoreConfiguration
 
lockAcquistionTimeout(long) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
lockAndRecord(Object, InvocationContext, long) - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
lockAndRecord(Object, InvocationContext, long) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Acquires a lock of type lockType, on a specific entry in the cache.
lockAndRecord(Object, InvocationContext, long) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
lockAndRegisterBackupLock(TxInvocationContext, Object) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
The backup (non-primary) owners keep a "backup lock" for each key they received in a lock/prepare command.
lockAndRegisterBackupLock(TxInvocationContext, Object, boolean) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
lockConcurrencyLevel() - Method in class org.infinispan.configuration.cache.AbstractLockSupportCacheStoreConfiguration
 
lockConcurrencyLevel(int) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
LockContainer<L extends Lock> - Interface in org.infinispan.util.concurrent.locks.containers
A container for locks
lockContainer - Variable in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
LockControlCommand - Class in org.infinispan.commands.control
LockControlCommand is a command that enables distributed locking across infinispan nodes.
LockControlCommand(String) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
LockControlCommand(Collection<Object>, String, Set<Flag>, GlobalTransaction) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
LockControlCommand(Object, String, Set<Flag>, GlobalTransaction) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
lockedKeys - Variable in class org.infinispan.context.impl.NonTxInvocationContext
 
lockedKeys - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
lockForReading(L) - Method in class org.infinispan.loaders.LockSupportCacheStore
Acquires read lock on the given key.
lockForWriting(L) - Method in class org.infinispan.loaders.LockSupportCacheStore
Acquires write lock on the given key.
LockInfo - Class in org.infinispan.statetransfer
Utility class used for lock transfer during topology changes.
LockInfo(GlobalTransaction, Object) - Constructor for class org.infinispan.statetransfer.LockInfo
 
LockInfo.Externalizer - Class in org.infinispan.statetransfer
 
LockInfo.Externalizer() - Constructor for class org.infinispan.statetransfer.LockInfo.Externalizer
 
locking() - Method in class org.infinispan.configuration.cache.Configuration
 
locking() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
locking() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
LockingConfiguration - Class in org.infinispan.configuration.cache
Defines the local, in-VM locking and concurrency characteristics of the cache.
LockingConfigurationBuilder - Class in org.infinispan.configuration.cache
Defines the local, in-VM locking and concurrency characteristics of the cache.
LockingConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
lockingMode(LockingMode) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
lockingMode - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
lockingMode(LockingMode) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
lockingMode(LockingMode) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. Configures whether the cache uses optimistic or pessimistic locking.
lockingMode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Configures whether the cache uses optimistic or pessimistic locking.
lockingMode(LockingMode) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Configures whether the cache uses optimistic or pessimistic locking.
LockingMode - Enum in org.infinispan.transaction
Defines the locking modes that are available for transactional caches: optimistic or pessimistic.
lockInterruptibly() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
lockKey(InvocationContext, Object) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
lockKeyAndCheckOwnership(InvocationContext, Object) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
Besides acquiring a lock, this method also handles the following situation: 1.
LockManager - Interface in org.infinispan.util.concurrent.locks
An interface to deal with all aspects of acquiring and releasing locks for cache entries.
LockManagerFactory - Class in org.infinispan.factories
Factory class that creates instances of LockManager.
LockManagerFactory() - Constructor for class org.infinispan.factories.LockManagerFactory
 
LockManagerImpl - Class in org.infinispan.util.concurrent.locks
Handles locks for the MVCC based LockingInterceptor
LockManagerImpl() - Constructor for class org.infinispan.util.concurrent.locks.LockManagerImpl
 
locks - Variable in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
locksAcquired(Collection<Address>) - Method in class org.infinispan.transaction.LocalTransaction
 
locksAtOrigin - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
LockSupportCacheStore<L> - Class in org.infinispan.loaders
This class extends AbstractCacheStore adding lock support for consistently accessing stored data.
LockSupportCacheStore() - Constructor for class org.infinispan.loaders.LockSupportCacheStore
 
LockSupportCacheStoreConfig - Class in org.infinispan.loaders
Adds configuration support for LockSupportCacheStore.
LockSupportCacheStoreConfig() - Constructor for class org.infinispan.loaders.LockSupportCacheStoreConfig
 
Log - Interface in org.infinispan.cdi.util.logging
The JBoss Logging interface which defined the logging methods for the CDI integration.
Log - Interface in org.infinispan.client.hotrod.logging
Log abstraction for the hot rod client.
log - Static variable in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
Log - Interface in org.infinispan.loaders.bdbje.logging
Log abstraction for the bdbje cache store.
Log - Interface in org.infinispan.loaders.cassandra.logging
Log abstraction for the cassandra store.
Log - Interface in org.infinispan.loaders.cloud.logging
Log abstraction for the cloud cache store.
Log - Interface in org.infinispan.loaders.jdbc.logging
Log abstraction for the JDBC cache store.
Log - Interface in org.infinispan.loaders.jdbm.logging
Log abstraction for the JDBM cache store.
Log - Interface in org.infinispan.loaders.remote.logging
Log abstraction for the remote cache store.
Log - Interface in org.infinispan.lucene.logging
Log abstraction for the lucene directory.
log - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
Log - Interface in org.infinispan.query.logging
Log abstraction for the query module.
Log - Interface in org.infinispan.server.websocket.logging
Log abstraction for the websocket server.
log - Variable in class org.infinispan.tools.schema.AbstractTreeWalker
 
log - Static variable in class org.infinispan.transaction.tm.DummyTransactionManager
 
Log - Interface in org.infinispan.tree.logging
Log abstraction for the tree module.
Log - Interface in org.infinispan.util.logging
Infinispan's log abstraction layer on top of JBoss Logging.
logErrorAndThrowExceptionIfNeeded(int, HotRodClientException) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
LogFactory - Class in org.infinispan.client.hotrod.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.client.hotrod.logging.LogFactory
 
LogFactory - Class in org.infinispan.util.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.util.logging.LogFactory
 
logFlushTimeout - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
logFlushTimeout(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
logFlushTimeout(Long) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. This is the maximum amount of time to run a cluster-wide flush, to allow for syncing of transaction logs.
logFlushTimeoutDeprecated() - Method in interface org.infinispan.util.logging.Log
 
logger - Variable in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
logger - Variable in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
logger - Variable in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
 
LongAdder - Class in org.infinispan.util.concurrent.jdk8backported
One or more variables that together maintain an initially zero long sum.
LongAdder() - Constructor for class org.infinispan.util.concurrent.jdk8backported.LongAdder
Creates a new adder with initial sum of zero.
longValue() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Equivalent to LongAdder.sum().
lookedUpEntries - Variable in class org.infinispan.context.impl.NonTxInvocationContext
 
lookedUpEntries - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
lookupComponent(String, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
lookupComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
lookupEntry(Object) - Method in interface org.infinispan.context.EntryLookup
Retrieves an entry from the collection of looked up entries in the current scope.
lookupEntry(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
lookupEntry(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
lookupEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
lookupEntryFromCurrentTransaction() - Method in class org.infinispan.atomic.AtomicHashMapProxy
Looks up the CacheEntry stored in transactional context corresponding to this AtomicMap.
lookupFile(String) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
lookupFile(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
Looks up the file, see : FileLookupFactory.DefaultFileLookup.
lookupFile(String, ClassLoader) - Method in interface org.infinispan.util.FileLookup
Looks up the file, see : DefaultFileLookup.
lookupFileLocation(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
 
lookupFileLocation(String, ClassLoader) - Method in interface org.infinispan.util.FileLookup
 
lookupFileLocations(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
 
lookupFileLocations(String, ClassLoader) - Method in interface org.infinispan.util.FileLookup
 
lookupFileStrict(String, ClassLoader) - Method in class org.infinispan.util.AbstractFileLookup
Looks up the file, see : FileLookupFactory.DefaultFileLookup.
lookupFileStrict(String, ClassLoader) - Method in interface org.infinispan.util.FileLookup
Looks up the file, see : DefaultFileLookup.
lookupLocalComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
lookupMBeanServer(GlobalConfiguration) - Static method in class org.infinispan.jmx.JmxUtil
Looks up the MBeanServer instance based on the configuration parameters.
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
A mechanism to loop over all buckets in the cache store.
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.file.FileCacheStore
 
loopOverBuckets(BucketBasedCacheStore.BucketHandler) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
LuceneKey2StringMapper - Class in org.infinispan.lucene
To configure a JdbcStringBasedCacheStoreConfig for the Lucene Directory, use this Key2StringMapper implementation.
LuceneKey2StringMapper() - Constructor for class org.infinispan.lucene.LuceneKey2StringMapper
 

M

machineId(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. The id of the machine where this node runs.
machineId - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
machineId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
machineId() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
machineId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
The id of the machine where this node runs.
main(String[]) - Static method in class org.infinispan.cdi.util.Version
Main method used to display the extension version.
main(String[]) - Static method in class org.infinispan.config.parsing.ConfigFilesConvertor
usage : java org.jboss.cache.config.parsing.ConfigFilesConvertor -Dsource=config-2.x.xml -Ddestination=config-3.x.xnl
main(String[]) - Static method in class org.infinispan.configuration.parsing.ConfigFilesConvertor
usage : java org.jboss.cache.config.parsing.ConfigFilesConvertor -Dsource=config-2.x.xml -Ddestination=config-3.x.xnl
main(String...) - Static method in class org.infinispan.demo.distexec.PiApproximationDemo
 
main(String[]) - Static method in class org.infinispan.demo.InfinispanDemo
 
main(String...) - Static method in class org.infinispan.demo.mapreduce.WordCountDemo
 
main(String[]) - Static method in class org.infinispan.demo.nearcache.client.TestingJmsClient
 
main(String[]) - Static method in class org.infinispan.demo.nearcache.server.MessagingHotRodDemo
 
main(String[]) - Static method in class org.infinispan.demos.directory.FilesystemDirectory
 
main(String[]) - Static method in class org.infinispan.ec2demo.InfinispanFluDemo
 
main(String[]) - Static method in class org.infinispan.factories.components.ComponentMetadataPersister
Usage: ComponentMetadataPersister [path containing .class files to scan] [output file to generate]
main(String[]) - Static method in class org.infinispan.lucenedemo.DemoDriver
 
main(String[]) - Static method in class org.infinispan.tools.rhq.RhqPluginXmlGenerator
 
main(String[]) - Static method in class org.infinispan.Version
Prints version information.
MAJOR_MINOR - Static variable in class org.infinispan.Version
 
makeConcurrentMap() - Static method in class org.infinispan.util.concurrent.ConcurrentMapFactory
 
makeConcurrentMap(int) - Static method in class org.infinispan.util.concurrent.ConcurrentMapFactory
 
makeConcurrentMap(int, int) - Static method in class org.infinispan.util.concurrent.ConcurrentMapFactory
 
makeConcurrentMap(int, float, int) - Static method in class org.infinispan.util.concurrent.ConcurrentMapFactory
 
makeLock(String) - Method in class org.infinispan.lucene.locking.BaseLockFactory
makeLock(String) - Method in class org.infinispan.lucene.locking.TransactionalLockFactory
makeObject(Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
ManageableComponentMetadata - Class in org.infinispan.factories.components
A specialization of ComponentMetadata, this version also includes JMX related metadata, as expressed by MBean, ManagedAttribute and ManagedOperation annotations.
ManageableComponentMetadata(Class<?>, List<Method>, List<Method>, List<Method>, boolean, boolean, List<Field>, List<Method>, List<Method>, MBean) - Constructor for class org.infinispan.factories.components.ManageableComponentMetadata
 
manageConnectionFactory - Variable in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
ManagedAttribute - Annotation Type in org.infinispan.jmx.annotations
Indicates that a public method or a field (any visibility) in an MBean class defines an MBean attribute.
ManagedConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Connection factory that can be used when on managed environments, like application servers.
ManagedConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
ManagedOperation - Annotation Type in org.infinispan.jmx.annotations
Indicates that a method in an MBean class defines an MBean operation.
map(String, String, Collector<String, Integer>) - Method in class org.infinispan.demo.mapreduce.WordCountMapper
 
map(KIn, VIn, Collector<KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.Mapper
Invoked once for each input cache entry KIn,VOut pair.
map - Variable in class org.infinispan.util.concurrent.ConcurrentHashSet
 
map(K) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.MappingFunction
Returns a non-null value for the given key.
MapExternalizer - Class in org.infinispan.marshall.exts
Map externalizer for all map implementations except immutable maps and singleton maps, i.e.
MapExternalizer() - Constructor for class org.infinispan.marshall.exts.MapExternalizer
 
mapKeysToNodes(K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
mapKeysToNodes() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
mappedWith(Mapper<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Specifies Mapper to use for this MapReduceTask
Mapper<KIn,VIn,KOut,VOut> - Interface in org.infinispan.distexec.mapreduce
Implementation of a Mapper class is a component of a MapReduceTask invoked once for each input entry K,V.
MapReduceCommand - Class in org.infinispan.commands.read
MapReduceCommand is used to migrate Mapper and Reducer to remote JVM where they will get invoked.
MapReduceCommand(String) - Constructor for class org.infinispan.commands.read.MapReduceCommand
 
MapReduceCommand(Mapper, Reducer, String, Object...) - Constructor for class org.infinispan.commands.read.MapReduceCommand
 
MapReduceCommand(Mapper, Reducer, String, Collection<Object>) - Constructor for class org.infinispan.commands.read.MapReduceCommand
 
MapReduceTask<KIn,VIn,KOut,VOut> - Class in org.infinispan.distexec.mapreduce
MapReduceTask is a distributed task allowing a large scale computation to be transparently parallelized across Infinispan cluster nodes.
MapReduceTask(Cache<KIn, VIn>) - Constructor for class org.infinispan.distexec.mapreduce.MapReduceTask
Create a new MapReduceTask given a master cache node.
MAPS - Static variable in interface org.infinispan.marshall.Ids
 
markCompleted(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Called when after the 2nd phase of a 2PC is successful.
markForRollback(boolean) - Method in class org.infinispan.transaction.LocalTransaction
 
markMarshallable(Class<?>, boolean) - Method in class org.infinispan.marshall.MarshallableTypeHints
Marks a particular type as being marshallable or not being not marshallable.
markRemoved(boolean) - Method in class org.infinispan.atomic.AtomicHashMap
 
markTransactionAsRemote(boolean) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
markTransactionAsRemote(boolean) - Method in interface org.infinispan.commands.tx.TransactionBoundaryCommand
 
marshal(Configuration.ClusteringType) - Method in class org.infinispan.config.Configuration.ClusteringTypeAdapter
Deprecated.  
marshal(TypedProperties) - Method in class org.infinispan.config.TypedPropertiesAdapter
 
marshall(StreamingMarshaller, Object) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
marshallableTypeHints - Variable in class org.infinispan.marshall.AbstractMarshaller
 
MarshallableTypeHints - Class in org.infinispan.marshall
Class providing hints about marshallable types, such as whether a particular type is marshallable or not, or an accurate approach to the serialized size of a particular type.
MarshallableTypeHints() - Constructor for class org.infinispan.marshall.MarshallableTypeHints
 
marshallCollection(Collection<?>, ObjectOutput) - Static method in class org.infinispan.marshall.MarshallUtil
 
MARSHALLED_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
MarshalledValue - Class in org.infinispan.marshall
Wrapper that wraps cached data, providing lazy deserialization using the calling thread's context class loader.
MarshalledValue(Object, boolean, StreamingMarshaller) - Constructor for class org.infinispan.marshall.MarshalledValue
 
MarshalledValue.Externalizer - Class in org.infinispan.marshall
 
MarshalledValue.Externalizer(StreamingMarshaller) - Constructor for class org.infinispan.marshall.MarshalledValue.Externalizer
 
MarshalledValueByteStream - Class in org.infinispan.io
A stream of bytes which can be written to, and the underlying byte array can be directly accessed.
MarshalledValueByteStream() - Constructor for class org.infinispan.io.MarshalledValueByteStream
 
MarshalledValueInterceptor - Class in org.infinispan.interceptors
Interceptor that handles the wrapping and unwrapping of cached data using MarshalledValues.
MarshalledValueInterceptor() - Constructor for class org.infinispan.interceptors.MarshalledValueInterceptor
 
marshaller - Variable in class org.infinispan.CacheImpl
 
MARSHALLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
marshaller() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
marshaller(Marshaller) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Set the marshaller instance that will marshall and unmarshall cache entries.
marshaller - Variable in class org.infinispan.distexec.DefaultExecutorService
 
marshaller - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
marshaller - Variable in class org.infinispan.loaders.AbstractCacheLoader
 
marshaller - Variable in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
marshaller - Variable in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
Marshaller - Interface in org.infinispan.marshall
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
marshaller - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
MarshallerAdapter - Class in org.infinispan.remoting.transport.jgroups
Bridge between JGroups and Infinispan marshallers
MarshallerAdapter(StreamingMarshaller) - Constructor for class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
marshallerClass(Class<? extends Marshaller>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Fully qualified name of the marshaller to use.
marshallerClass - Variable in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
marshallerClass(Class<? extends Marshaller>) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
MarshallerFactory - Class in org.infinispan.factories
MarshallerFactory.
MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
 
marshallMap(Map<?, ?>, ObjectOutput) - Static method in class org.infinispan.marshall.MarshallUtil
 
MarshallUtil - Class in org.infinispan.marshall
MarshallUtil.
MarshallUtil() - Constructor for class org.infinispan.marshall.MarshallUtil
 
max - Variable in class org.infinispan.query.impl.AbstractIterator
 
MAX_BATCH_SIZE - Static variable in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
 
MAX_ID - Static variable in interface org.infinispan.marshall.Ids
 
maxEntries - Variable in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
maxEntries(Integer) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
maxEntries(Integer) - Method in interface org.infinispan.config.FluentConfiguration.EvictionConfig
Deprecated. Maximum number of entries in a cache instance.
maxEntries() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Maximum number of entries in a cache instance.
maxEntries(int) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Maximum number of entries in a cache instance.
maxIdle - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
maxIdle - Variable in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
maxIdle(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
maxIdle(Long) - Method in interface org.infinispan.config.FluentConfiguration.ExpirationConfig
Deprecated. Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
maxIdle() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
maxIdle(long) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
maxIdle - Variable in class org.infinispan.container.entries.TransientCacheValue
 
maxIdle - Variable in class org.infinispan.container.entries.TransientMortalCacheValue
 
maxNonProgressingLogWrites - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
maxNonProgressingLogWrites(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
maxNonProgressingLogWrites(Integer) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. This is the maximum number of non-progressing transaction log writes after which a brute-force flush approach is resorted to, to synchronize transaction logs.
maxProgressingLogWritesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
maxResults(int) - Method in interface org.infinispan.query.CacheQuery
Sets the maximum number of results to the number passed in as a parameter.
maxResults(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
MBean - Annotation Type in org.infinispan.jmx.annotations
Classes annotated with this will be exposed as MBeans.
MBeanAttribute - Class in org.infinispan.tools.doclet.jmx
An MBean attribute
MBeanAttribute() - Constructor for class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
MBeanComponent - Class in org.infinispan.tools.doclet.jmx
* An MBean component
MBeanComponent() - Constructor for class org.infinispan.tools.doclet.jmx.MBeanComponent
 
MBeanOperation - Class in org.infinispan.tools.doclet.jmx
An MBean operation
MBeanOperation() - Constructor for class org.infinispan.tools.doclet.jmx.MBeanOperation
 
mBeanServerLookup(MBeanServerLookup) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated. Sets the instance of the MBeanServerLookup class to be used to bound JMX MBeans to.
mBeanServerLookup - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
mBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
mbeanServerLookup() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
mBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Sets the instance of the MBeanServerLookup class to be used to bound JMX MBeans to.
MBeanServerLookup - Interface in org.infinispan.jmx
Implementors of this should return an MBeanServer to which MBeans will be registered.
mBeanServerLookupClass(Class<? extends MBeanServerLookup>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated. Instance of class that will attempt to locate a JMX MBean server to bind to
mBeanServerLookupClass(Class<? extends MBeanServerLookup>) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
mbeansSuccessfullyRegistered() - Method in interface org.infinispan.util.logging.Log
 
members - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
members - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
MembershipArithmetic - Class in org.infinispan.remoting
A helper to perform common arithmetic functions with membership lists
MembershipArithmetic() - Constructor for class org.infinispan.remoting.MembershipArithmetic
 
merge(DeltaAware) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
merge(DeltaAware) - Method in interface org.infinispan.atomic.Delta
Merge the current Delta instance with a given DeltaAware instance, and return a coherent and complete DeltaAware instance.
merge(DeltaAware) - Method in enum org.infinispan.atomic.NullDelta
 
merge(EntryVersionsMap) - Method in class org.infinispan.container.versioning.EntryVersionsMap
 
Merged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology experiences a merge event after a cluster split.
MergeEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with Merged.
messageId(long) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.infinispan.server.websocket.WebSocketServerHandler
 
MessagingHotRodDemo - Class in org.infinispan.demo.nearcache.server
Hot Rod and JMS messaging server
MessagingHotRodDemo() - Constructor for class org.infinispan.demo.nearcache.server.MessagingHotRodDemo
 
MessagingHotRodDemo.InvalidationProducer - Class in org.infinispan.demo.nearcache.server
 
MessagingHotRodDemo.InvalidationProducer(Session, Topic) - Constructor for class org.infinispan.demo.nearcache.server.MessagingHotRodDemo.InvalidationProducer
 
metadata - Variable in class org.infinispan.io.GridFilesystem
 
metadataCacheName - Static variable in class org.infinispan.demos.gridfs.CacheManagerHolder
 
method - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
MethodMetaData<A extends Annotation> - Class in org.infinispan.cdi.interceptor.context.metadata
Metadata associated to a method annotated with a cache annotation.
MethodMetaData(Method, AggregatedParameterMetaData, Set<Annotation>, CacheKeyGenerator, A, String) - Constructor for class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
methodWithoutCacheAnnotation(String) - Method in interface org.infinispan.cdi.util.logging.Log
 
MIME - Static variable in interface org.infinispan.server.websocket.OpHandler
 
MIMECacheEntry - Class in org.infinispan.remoting
Wrapper object for entries that arrive via RESTful PUT/POST interface.
MIMECacheEntry() - Constructor for class org.infinispan.remoting.MIMECacheEntry
 
MIMECacheEntry(String, byte[]) - Constructor for class org.infinispan.remoting.MIMECacheEntry
 
MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get misses.
missingListPreparedTransactions(Object, Object) - Method in interface org.infinispan.util.logging.Log
 
missingRequired(XMLStreamReader, Set<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting a missing, required XML attribute.
missingRequiredElement(XMLStreamReader, Set<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting a missing, required XML child element.
mkdir() - Method in class org.infinispan.io.GridFile
 
mkdirs() - Method in class org.infinispan.io.GridFile
 
mode - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
mode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
mode(Configuration.CacheMode) - Method in interface org.infinispan.config.FluentConfiguration.ClusteringConfig
Deprecated. Cache mode.
modelGroup(XSModelGroup) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
modelGroupDecl(XSModelGroupDecl) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
Modification - Interface in org.infinispan.loaders.modifications
An interface that defines a CacheStore modification
Modification.Type - Enum in org.infinispan.loaders.modifications
 
modificationQueueSize() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
Sets the size of the modification queue for the async store.
modificationQueueSize(int) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
Sets the size of the modification queue for the async store.
modificationQueueSize - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
modificationQueueSize(Integer) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
modifications - Variable in class org.infinispan.commands.tx.PrepareCommand
 
modifications - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
ModificationsList - Class in org.infinispan.loaders.modifications
ModificationsList contains a List
ModificationsList(List<? extends Modification>) - Constructor for class org.infinispan.loaders.modifications.ModificationsList
 
ModificationsTransactionWorker - Class in org.infinispan.loaders.bdbje
Adapter that allows a list of Modifications to be performed atomically via TransactionRunner.
ModificationsTransactionWorker(CacheStore, List<? extends Modification>) - Constructor for class org.infinispan.loaders.bdbje.ModificationsTransactionWorker
Associates Modifications that will be applied to the supplied CacheStore
MODULE_COMMAND_FACTORIES - Static variable in class org.infinispan.factories.KnownComponentNames
 
MODULE_COMMAND_INITIALIZERS - Static variable in class org.infinispan.factories.KnownComponentNames
 
moduleCacheRpcCommands() - Method in class org.infinispan.util.ModuleProperties
 
ModuleCommandExtensions - Interface in org.infinispan.commands.module
Module command extensions
moduleCommandFactories() - Method in class org.infinispan.util.ModuleProperties
 
ModuleCommandFactory - Interface in org.infinispan.commands.module
Modules which wish to implement their own commands and visitors must also provide an implementation of this interface and declare it in their infinispan-module.properties file under key infinispan.module.command.factory.
ModuleCommandIds - Interface in org.infinispan.query
The Query module is using custom RPC commands; to make sure the used command ids are unique all numbers are defined here, and should stay in the range 100-119 which is the reserved range for this module.
ModuleCommandInitializer - Interface in org.infinispan.commands.module
Modules which wish to implement their own commands and visitors must also provide an implementation of this interface and declare it in their infinispan-module.properties file under key infinispan.module.command.initializer.
moduleCommandInitializers() - Method in class org.infinispan.util.ModuleProperties
 
moduleCommands() - Method in class org.infinispan.util.ModuleProperties
 
ModuleLifecycle - Interface in org.infinispan.lifecycle
ModuleLifecycle is an internal API hook for delegating lifecycle events to Infinispan sub-modules.
ModuleMetadataFileFinder - Interface in org.infinispan.factories.components
This interface should be implemented by all Infinispan modules that expect to have components using Inject, Start or Stop annotations.
moduleOnlyReplicableCommands() - Method in class org.infinispan.util.ModuleProperties
 
ModuleProperties - Class in org.infinispan.util
The ModuleProperties class represents Infinispan's module service extensions
ModuleProperties() - Constructor for class org.infinispan.util.ModuleProperties
 
MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
MORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
MortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is mortal.
MortalCacheEntry(Object, MortalCacheValue) - Constructor for class org.infinispan.container.entries.MortalCacheEntry
 
MortalCacheEntry(Object, Object, long) - Constructor for class org.infinispan.container.entries.MortalCacheEntry
 
MortalCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheEntry
 
MortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
MortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
MortalCacheValue - Class in org.infinispan.container.entries
A mortal cache value, to correspond with MortalCacheEntry
MortalCacheValue(Object, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheValue
 
MortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
MortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
move(Fqn, Fqn) - Method in interface org.infinispan.tree.TreeCache
Moves a part of the cache to a different subtree.
move(Fqn, Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
move(String, String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes in string representations of Fqns.
move(String, String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
move(Fqn, Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(Fqn, Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(String, String) - Method in class org.infinispan.tree.TreeCacheImpl
 
move(String, String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
msgOrMsgBufferEmpty() - Method in interface org.infinispan.util.logging.Log
 
multipleKeys() - Method in class org.infinispan.commands.control.LockControlCommand
 
MultipleRpcCommand - Class in org.infinispan.commands.remote
Command that implements cluster replication logic.
MultipleRpcCommand(List<ReplicableCommand>, String) - Constructor for class org.infinispan.commands.remote.MultipleRpcCommand
 
MultipleRpcCommand(String) - Constructor for class org.infinispan.commands.remote.MultipleRpcCommand
 
multiThreadedPurge - Variable in class org.infinispan.loaders.AbstractCacheStore
 
MurmurHash2 - Class in org.infinispan.commons.hash
An implementation of Austin Appleby's MurmurHash2.0 algorithm, as documented on his website.
MurmurHash2() - Constructor for class org.infinispan.commons.hash.MurmurHash2
 
MurmurHash2.Externalizer - Class in org.infinispan.commons.hash
 
MurmurHash2.Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash2.Externalizer
 
MurmurHash2Compat - Class in org.infinispan.commons.hash
An implementation of Austin Appleby's MurmurHash2.0 algorithm, as documented on his website.
MurmurHash2Compat() - Constructor for class org.infinispan.commons.hash.MurmurHash2Compat
 
MurmurHash2Compat.Externalizer - Class in org.infinispan.commons.hash
 
MurmurHash2Compat.Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash2Compat.Externalizer
 
MurmurHash3 - Class in org.infinispan.commons.hash
MurmurHash3 implementation in Java, based on Austin Appleby's original in C Only implementing x64 version, because this should always be faster on 64 bit native processors, even 64 bit being ran with a 32 bit OS; this should also be as fast or faster than the x86 version on some modern 32 bit processors.
MurmurHash3() - Constructor for class org.infinispan.commons.hash.MurmurHash3
 
MurmurHash3.Externalizer - Class in org.infinispan.commons.hash
 
MurmurHash3.Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
MurmurHash3_x64_128(byte[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hash a value using the x64 128 bit variant of MurmurHash3
MurmurHash3_x64_128(long[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hash a value using the x64 128 bit variant of MurmurHash3
MurmurHash3_x64_32(byte[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hash a value using the x64 32 bit variant of MurmurHash3
MurmurHash3_x64_32(long[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hash a value using the x64 32 bit variant of MurmurHash3
MurmurHash3_x64_64(byte[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hash a value using the x64 64 bit variant of MurmurHash3
MurmurHash3_x64_64(long[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hash a value using the x64 64 bit variant of MurmurHash3
MURMURHASH_2 - Static variable in interface org.infinispan.marshall.Ids
 
MURMURHASH_2_COMPAT - Static variable in interface org.infinispan.marshall.Ids
 
MURMURHASH_3 - Static variable in interface org.infinispan.marshall.Ids
 
MVCCEntry - Interface in org.infinispan.container.entries
An entry that can be safely copied when updates are made, to provide MVCC semantics

N

name - Variable in class org.infinispan.config.Configuration
Deprecated.  
name - Variable in class org.infinispan.tools.doclet.jmx.JmxComponent
 
NAME_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
namedCacheDoesNotExist(String) - Method in interface org.infinispan.util.logging.Log
 
NamedCacheNotFoundException - Exception in org.infinispan.manager
Thrown when a named cache cannot be found.
NamedCacheNotFoundException(String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
NamedCacheNotFoundException(String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
 
namedCaches - Variable in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory.ConfigurationContainer
 
NamedComponentFactory - Class in org.infinispan.factories
A specialized type of component factory that knows how to create named components, identified with the ComponentName annotation on the classes requested in Inject annotated methods.
NamedComponentFactory() - Constructor for class org.infinispan.factories.NamedComponentFactory
 
NamedExecutorsFactory - Class in org.infinispan.factories
A factory that specifically knows how to create named executors.
NamedExecutorsFactory() - Constructor for class org.infinispan.factories.NamedExecutorsFactory
 
Namespace - Enum in org.infinispan.configuration.parsing
An enumeration of the supported domain model namespaces.
NamespaceFilter - Class in org.infinispan.config.parsing
Adds namespace where needed when parsing an XML document
NamespaceFilter() - Constructor for class org.infinispan.config.parsing.NamespaceFilter
 
namingExceptionLookingUpConnection(String, NamingException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
NaturalComparator<T> - Class in org.infinispan.loaders.jdbm
Compares keys using their natural ordering.
NaturalComparator() - Constructor for class org.infinispan.loaders.jdbm.NaturalComparator
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
 
needMoreResponses() - Method in interface org.infinispan.remoting.rpc.ResponseFilter
Right after calling ResponseFilter.isAcceptable(Response, Address), this method is called to see whether we are done with the request and can unblock the caller
needMoreResponses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsResponseFilterAdapter
 
needToDestroyFailedCache() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
needToInitializeBeforeStart() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
newBulkGetOperation(int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newCatchThrowableProxy(Object) - Static method in class org.infinispan.util.Proxies
 
newClearOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newCondition() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
newConfigurationBuilder(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
newConsistentHash(int) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
newContainsKeyOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newFaultTolerantPingOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
Construct a fault tolerant ping request.
newFixedThreadPool(int, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue.
newFixedThreadPool(int, ThreadFactory, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue, using the provided ThreadFactory to create new threads when needed.
newGetKeyOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGetWithVersionOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGlobalTransaction() - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newGlobalTransaction(Address, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newGlobalTransaction(Address, boolean, ClusterIdGenerator, boolean) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newGlobalTransaction() - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newInfinispanConfiguration(String, String, ClassLoader) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(String, String, ConfigurationBeanVisitor, ClassLoader) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(String, ClassLoader) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(InputStream) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(Reader) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(InputStream, InputStream) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(Reader, InputStream) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(Reader, InputStream, ConfigurationBeanVisitor) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInfinispanConfiguration(InputStream, InputStream, ConfigurationBeanVisitor) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Factory method to create an instance of Infinispan configuration.
newInstance(Cache<Object, Object>, Object) - Static method in class org.infinispan.atomic.AtomicHashMap
Construction only allowed through this factory method.
newInstance() - Static method in class org.infinispan.util.FileLookupFactory
 
newKeyAffinityService(Cache<K, V>, Executor, KeyGenerator<K>, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Creates an KeyAffinityService instance that generates keys mapped to all addresses in the cluster.
newKeyAffinityService(Cache<K, V>, Executor, KeyGenerator<K>, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.concurrent.Executor, KeyGenerator, int, boolean) with start == true;
newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator<K>, Executor, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Creates a service that would only generate keys for addresses specified in filter.
newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator<K>, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Same as KeyAffinityServiceFactory.newKeyAffinityService(org.infinispan.Cache, java.util.Collection, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
NEWLINE - Static variable in class org.infinispan.util.StringPropertyReplacer
New line string constant
newLocalKeyAffinityService(Cache<K, V>, KeyGenerator<K>, Executor, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Created an service that only generates keys for the local address.
newLocalKeyAffinityService(Cache<K, V>, KeyGenerator<K>, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
Same as KeyAffinityServiceFactory.newLocalKeyAffinityService(org.infinispan.Cache, KeyGenerator, java.util.concurrent.Executor, int, boolean) with start == true.
newLocalTransaction(Transaction, GlobalTransaction, boolean, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newLocalTransaction(Transaction, GlobalTransaction, boolean, int) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
newLock() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
newNonTxInvocationContext(boolean) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
newPingOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
Construct a ping request directed to a particular node.
newPutIfAbsentOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newPutKeyValueOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newRemoteTransaction(WriteCommand[], GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newRemoteTransaction(GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newRemoteTransaction(WriteCommand[], GlobalTransaction, int) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newRemoteTransaction(GlobalTransaction, int) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newRemoveIfUnmodifiedOperation(byte[], long) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newRemoveOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newReplaceIfUnmodifiedOperation(byte[], byte[], int, int, long) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newReplaceOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newServerAdded(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
newStatsOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newTaskFor(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
 
newTaskFor(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
newTopology(SocketAddress, int, int, Set<SocketAddress>) - Method in interface org.infinispan.client.hotrod.logging.Log
 
newVersion(boolean) - Method in class org.infinispan.util.ClusterIdGenerator
 
newViewId - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
next() - Method in class org.infinispan.container.DefaultDataContainer.EntryIterator
 
next() - Method in class org.infinispan.query.clustered.DistributedIterator
 
next() - Method in class org.infinispan.query.impl.EagerIterator
Returns the next element in the list
next() - Method in class org.infinispan.query.impl.LazyIterator
 
next() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
next(int) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
 
nextDouble(double) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed double value between 0 (inclusive) and the specified value (exclusive).
nextDouble(double, double) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextElement(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
nextIndex() - Method in class org.infinispan.query.clustered.DistributedIterator
 
nextIndex() - Method in class org.infinispan.query.impl.EagerIterator
Returns the index of the element that would be returned by a subsequent call to next.
nextIndex() - Method in class org.infinispan.query.impl.LazyIterator
 
nextInt(int, int) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextLong(long) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between 0 (inclusive) and the specified value (exclusive).
nextLong(long, long) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextServer() - Method in interface org.infinispan.client.hotrod.impl.transport.tcp.RequestBalancingStrategy
 
nextServer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
Multiple threads might call this method at the same time.
nextSize(Object) - Method in class org.infinispan.marshall.AdaptiveBufferSizePredictor
 
nextSize(Object) - Method in interface org.infinispan.marshall.BufferSizePredictor
Provide the next buffer size taking in account the object to store in the buffer.
NO_BLOCKING_CACHE_VIEW - Static variable in interface org.infinispan.statetransfer.StateTransferLock
 
NO_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
NO_OPTIONS - Static variable in class org.infinispan.util.Base64
No options specified.
noAnnotateMethodsFoundInListener(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
Node<K,V> - Interface in org.infinispan.tree
A Node is a named logical grouping of data in the TreeCache API of JBoss Cache.
NodeImpl<K,V> - Class in org.infinispan.tree
Implementation backed by an AtomicMap
NodeImpl(Fqn, AdvancedCache<?, ?>, BatchContainer) - Constructor for class org.infinispan.tree.NodeImpl
 
NodeKey - Class in org.infinispan.tree
A class that represents the key to a node
NodeKey(Fqn, NodeKey.Type) - Constructor for class org.infinispan.tree.NodeKey
 
NodeKey.Externalizer - Class in org.infinispan.tree
 
NodeKey.Externalizer() - Constructor for class org.infinispan.tree.NodeKey.Externalizer
 
NodeKey.Type - Enum in org.infinispan.tree
 
nodeName(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. Name of the current node.
nodeName - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
nodeName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
nodeName() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
nodeName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Name of the current node.
NodeNotExistsException - Exception in org.infinispan.tree
Thrown when an operation is attempted on a non-existing node in the cache
NodeNotExistsException() - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotExistsException(String) - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotExistsException(String, Throwable) - Constructor for exception org.infinispan.tree.NodeNotExistsException
 
NodeNotValidException - Exception in org.infinispan.tree
Thrown whenever operations are attempted on a node that is no longer valid.
NodeNotValidException() - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(Throwable) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(String) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
NodeNotValidException(String, Throwable) - Constructor for exception org.infinispan.tree.NodeNotValidException
 
noHasHFunctionConfigured(int) - Method in interface org.infinispan.client.hotrod.logging.Log
 
nonClusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
NonTransactionalInvocationContextContainer - Class in org.infinispan.context
Invocation Context container to be used for non-transactional caches.
NonTransactionalInvocationContextContainer() - Constructor for class org.infinispan.context.NonTransactionalInvocationContextContainer
 
NonTransactionalLockingInterceptor - Class in org.infinispan.interceptors.locking
Locking interceptor to be used for non-transactional caches.
NonTransactionalLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
NonTxInvocationContext - Class in org.infinispan.context.impl
Context to be used for non transactional calls, both remote and local.
NonTxInvocationContext(int, boolean) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NonTxInvocationContext() - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NoOpFuture<E> - Class in org.infinispan.util.concurrent
A future that doesn't do anything and simply returns a given return value.
NoOpFuture(E) - Constructor for class org.infinispan.util.concurrent.NoOpFuture
 
NoopSegmentReadLocker - Class in org.infinispan.lucene.readlocks
NoopSegmentReadLocker ignores requests to apply a readlock, but also ignores requests to delete files.
NoopSegmentReadLocker() - Constructor for class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
 
NoReturnValuesDistributionResponseGenerator - Class in org.infinispan.remoting.responses
 
NoReturnValuesDistributionResponseGenerator() - Constructor for class org.infinispan.remoting.responses.NoReturnValuesDistributionResponseGenerator
 
NoStateExternalizer<T> - Class in org.infinispan.marshall.exts
An externalizer that writes no state.
NoStateExternalizer() - Constructor for class org.infinispan.marshall.exts.NoStateExternalizer
 
NOT_PUT_REMOVED_REPLACED_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
notation(XSNotation) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
NOTHING - Static variable in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
 
NotificationInterceptor - Class in org.infinispan.interceptors
The interceptor in charge of firing off notifications to cache listeners
NotificationInterceptor() - Constructor for class org.infinispan.interceptors.NotificationInterceptor
 
notifier - Variable in class org.infinispan.CacheImpl
 
notifier - Variable in class org.infinispan.commands.tx.PrepareCommand
 
notifier - Variable in class org.infinispan.commands.write.RemoveCommand
 
notifier - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
notifier - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.EvictCommand
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.InvalidateCommand
 
notify(InvocationContext, Object, boolean) - Method in class org.infinispan.commands.write.RemoveCommand
 
notifyAfterCompletion(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
notifyBeforeCompletion() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
notifyCacheEntriesEvicted(Collection<InternalCacheEntry>, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntriesEvicted event.
notifyCacheEntriesEvicted(Collection<InternalCacheEntry>, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryActivated(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryActivated event.
notifyCacheEntryActivated(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryCreated(Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryCreated event.
notifyCacheEntryCreated(Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryEvicted(Object, Object, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Syntactic sugar
notifyCacheEntryEvicted(Object, Object, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryInvalidated(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryInvalidated event.
notifyCacheEntryInvalidated(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryLoaded(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryLoaded event.
notifyCacheEntryLoaded(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryModified(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryModified event.
notifyCacheEntryModified(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryPassivated(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryPassivated event.
notifyCacheEntryPassivated(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryRemoved(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryRemoved event.
notifyCacheEntryRemoved(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryVisited(Object, Object, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryVisited event.
notifyCacheEntryVisited(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheStarted(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyCacheStarted(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyCacheStopped(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyCacheStopped(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyDataRehashed(Collection<Address>, Collection<Address>, long, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyDataRehashed(Collection<Address>, Collection<Address>, long, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyDone() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
notifyDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
notifyDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
notifyDone() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
notifyDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
notifyDone() - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
notifyFutureCompletion() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
NotifyHandler - Class in org.infinispan.server.websocket.handlers
Handler for the "notify" and "unnotify" operations.
NotifyHandler() - Constructor for class org.infinispan.server.websocket.handlers.NotifyHandler
 
NotifyingFuture<T> - Interface in org.infinispan.util.concurrent
A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified of when the future completes.
NotifyingFutureImpl<T> - Class in org.infinispan.client.hotrod.impl.async
Notifying future implementation for async calls.
NotifyingFutureImpl() - Constructor for class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
NotifyingFutureImpl - Class in org.infinispan.util.concurrent
Constructs an instance of a NotifyingFuture.
NotifyingFutureImpl(Object) - Constructor for class org.infinispan.util.concurrent.NotifyingFutureImpl
 
NotifyingNotifiableFuture<T> - Interface in org.infinispan.util.concurrent
An internal interface which adds the ability to inform the future of completion.
notifyMerge(List<Address>, List<Address>, Address, int, List<List<Address>>) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
 
notifyMerge(List<Address>, List<Address>, Address, int, List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
notifyOnTransactionFinished() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
notifyOnTransactionFinished() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
notifyStateReceiptFailed(StateTransferException) - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
notifyStateReceiptSucceeded() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
notifyTopologyChanged(ConsistentHash, ConsistentHash, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyTopologyChanged(ConsistentHash, ConsistentHash, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction completion event.
notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyTransactionRegistered(GlobalTransaction, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction registration event.
notifyTransactionRegistered(GlobalTransaction, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyViewChange(List<Address>, List<Address>, Address, int) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
Notifies all registered listeners of a viewChange event.
notifyViewChange(List<Address>, List<Address>, Address, int) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
NotSerializableException - Exception in org.infinispan.marshall
An exception that hides inner stacktrace lines for non serializable exceptions.
NotSerializableException(String, Throwable) - Constructor for exception org.infinispan.marshall.NotSerializableException
 
NotSerializableException(String) - Constructor for exception org.infinispan.marshall.NotSerializableException
 
notStartingEvictionThread() - Method in interface org.infinispan.util.logging.Log
 
noTxModifications(InvocationContext) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
Nucleotide_Protein_Element - Class in org.infinispan.ec2demo
 
Nucleotide_Protein_Element() - Constructor for class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
Nucleotide_Protein_Parser - Class in org.infinispan.ec2demo
 
Nucleotide_Protein_Parser() - Constructor for class org.infinispan.ec2demo.Nucleotide_Protein_Parser
 
NucleotideCache - Class in org.infinispan.ec2demo
 
NucleotideCache(CacheBuilder) - Constructor for class org.infinispan.ec2demo.NucleotideCache
 
NullDelta - Enum in org.infinispan.atomic
Represents no changes.
NullMarkerEntry - Class in org.infinispan.container.entries
A marker entry to represent a null for repeatable read, so that a read that returns a null can continue to return null.
NullMarkerEntryForRemoval - Class in org.infinispan.container.entries
A null entry that is read in for removal
NullMarkerEntryForRemoval(Object, EntryVersion) - Constructor for class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
NUMERIC_NAMED_FILES_FILTER - Static variable in class org.infinispan.loaders.file.FileCacheStore
 
numOwners - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
numOwners(Integer) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
numOwners(Integer) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated. Number of cluster-wide replicas for each cache entry.
numOwners() - Method in class org.infinispan.configuration.cache.HashConfiguration
Number of cluster-wide replicas for each cache entry.
numOwners(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Number of cluster-wide replicas for each cache entry.
numRetries - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
numRetries(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
numRetries(Integer) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. Number of state retrieval retries before giving up and aborting startup.
numRetriesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
numVirtualNodes - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
numVirtualNodes(Integer) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
numVirtualNodes(Integer) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated. Controls the number of virtual nodes per "real" node.
numVirtualNodes() - Method in class org.infinispan.configuration.cache.HashConfiguration
Controls the number of virtual nodes per "real" node.
numVirtualNodes(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Controls the number of virtual nodes per "real" node.
numVirtualNodes - Variable in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 

O

OBJECT_NAME - Static variable in class org.infinispan.CacheImpl
 
OBJECT_NAME - Static variable in class org.infinispan.manager.DefaultCacheManager
 
ObjectDuplicator - Class in org.infinispan.util
A helper that efficiently duplicates known object types.
ObjectDuplicator() - Constructor for class org.infinispan.util.ObjectDuplicator
 
objectFromBuffer(byte[], int, int) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
objectFromByteBuffer(byte[]) - Method in interface org.infinispan.marshall.Marshaller
Unmarshalls an object from a byte array.
objectFromByteBuffer(byte[], int, int) - Method in interface org.infinispan.marshall.Marshaller
Unmarshalls an object from a specific portion of a byte array.
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.AbstractMarshaller
This method implements StreamingMarshaller.objectFromInputStream(java.io.InputStream), but its implementation has been moved here rather that keeping under a class that implements StreamingMarshaller in order to avoid code duplication.
objectFromInputStream(InputStream) - Method in interface org.infinispan.marshall.StreamingMarshaller
Unmarshall an object from an InputStream
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Unmarshalls an object from an ObjectInput
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.AbstractMarshaller
This is a convenience method for converting an object into a ByteBuffer which takes an estimated size as parameter.
objectToBuffer(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
objectToBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
A method that returns an instance of ByteBuffer, which allows direct access to the byte array with minimal array copying
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, int) - Method in interface org.infinispan.marshall.Marshaller
Marshalls an object to a byte array.
objectToByteBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
Marshalls an object to a byte array.
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Marshalls an object to a given ObjectOutput
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
oldValue - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
oldValue - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
onEntryChosenForEviction(V) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionListener
 
onEntryEviction(Map<Object, InternalCacheEntry>) - Method in interface org.infinispan.eviction.EvictionManager
 
onEntryEviction(Map<Object, InternalCacheEntry>) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
onEntryEviction(Map<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionListener
 
onEntryHit(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that an entry in Segment has been accessed.
onEntryMiss(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that there has been an attempt to access an entry in Segment, however that entry was not present in Segment.
onEntryRemove(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that an entry e has been removed from Segment.
onePhaseCommit - Variable in class org.infinispan.commands.tx.PrepareCommand
 
onKeys(KIn...) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Rather than use all available keys as input onKeys allows users to specify a subset of keys as input to this task
onMessage(Message) - Method in class org.infinispan.nearcache.jms.RemoteEventListener
 
onRehash - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.  
onRehash(Boolean) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
onRehash(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.L1Config
Deprecated. If true, entries removed due to a rehash will be moved to L1 rather than being removed altogether.
onRehash() - Method in class org.infinispan.configuration.cache.L1Configuration
If true, entries removed due to a rehash will be moved to L1 rather than being removed altogether.
onRehash(boolean) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Entries removed due to a rehash will be moved to L1 rather than being removed altogether.
onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.transaction.StaleTransactionCleanupService
Roll back remote transactions that have acquired lock that are no longer valid, either because the main data owner left the cluster or because a node joined the cluster and is the new data owner.
onViewChange(ViewChangedEvent) - Method in class org.infinispan.transaction.StaleTransactionCleanupService
Roll back remote transactions originating on nodes that have left the cluster.
OP_CODE - Static variable in interface org.infinispan.server.websocket.OpHandler
 
opCode(short) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
openInput(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Operation<K,V> - Class in org.infinispan.atomic
An atomic operation.
Operation() - Constructor for class org.infinispan.atomic.Operation
 
operations - Variable in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
OperationsFactory - Class in org.infinispan.client.hotrod.impl.operations
Factory for HotRodOperation objects.
OperationsFactory(TransportFactory, String, AtomicInteger, boolean, Codec) - Constructor for class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
OpHandler - Interface in org.infinispan.server.websocket
Websocket cache operation handler.
OptimisticLockingInterceptor - Class in org.infinispan.interceptors.locking
Locking interceptor to be used by optimistic transactional caches.
OptimisticLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
optionLength(String) - Static method in class org.infinispan.tools.doclet.config.ConfigDoclet
 
optionLength(String) - Static method in class org.infinispan.tools.doclet.jmx.JmxDoclet
 
org.infinispan - package org.infinispan
This is the core of Infinispan, a distributed, transactional, highly scalable data grid platform.
org.infinispan.affinity - package org.infinispan.affinity
 
org.infinispan.api - package org.infinispan.api
API package
org.infinispan.atomic - package org.infinispan.atomic
This package contains the AtomicMap interfaces and API that Infinispan exposes as building blocks in creating other public interfaces such as the Tree API.
org.infinispan.batch - package org.infinispan.batch
Support for batching calls using the Cache.startBatch() and Cache.endBatch(boolean) API.
org.infinispan.cacheviews - package org.infinispan.cacheviews
 
org.infinispan.cdi - package org.infinispan.cdi
This is the Infinispan CDI module.
org.infinispan.cdi.event - package org.infinispan.cdi.event
This package contains the event bridge implementation between Infinispan and CDI.
org.infinispan.cdi.event.cache - package org.infinispan.cdi.event.cache
This package contains the adapters making the bridge between Infinispan cache events and CDI.
org.infinispan.cdi.event.cachemanager - package org.infinispan.cdi.event.cachemanager
This package contains the adapters making the bridge between Infinispan cache manager events and CDI.
org.infinispan.cdi.interceptor - package org.infinispan.cdi.interceptor
This package provides the partial support of JCACHE (JSR-107).
org.infinispan.cdi.interceptor.context - package org.infinispan.cdi.interceptor.context
This package contains context implementation classes.
org.infinispan.cdi.interceptor.context.metadata - package org.infinispan.cdi.interceptor.context.metadata
This package contains metadata classes.
org.infinispan.cdi.interceptor.literal - package org.infinispan.cdi.interceptor.literal
This package contains the literal implementations of JCACHE annotations CacheResult, CacheRemoveEntry, CachePut and CacheRemoveAll.
org.infinispan.cdi.util - package org.infinispan.cdi.util
This package contains utility classes.
org.infinispan.cdi.util.logging - package org.infinispan.cdi.util.logging
This package contains the logging classes.
org.infinispan.client.hotrod - package org.infinispan.client.hotrod
 
org.infinispan.client.hotrod.exceptions - package org.infinispan.client.hotrod.exceptions
 
org.infinispan.client.hotrod.impl - package org.infinispan.client.hotrod.impl
 
org.infinispan.client.hotrod.impl.async - package org.infinispan.client.hotrod.impl.async
 
org.infinispan.client.hotrod.impl.consistenthash - package org.infinispan.client.hotrod.impl.consistenthash
 
org.infinispan.client.hotrod.impl.operations - package org.infinispan.client.hotrod.impl.operations
 
org.infinispan.client.hotrod.impl.protocol - package org.infinispan.client.hotrod.impl.protocol
 
org.infinispan.client.hotrod.impl.transport - package org.infinispan.client.hotrod.impl.transport
 
org.infinispan.client.hotrod.impl.transport.tcp - package org.infinispan.client.hotrod.impl.transport.tcp
 
org.infinispan.client.hotrod.logging - package org.infinispan.client.hotrod.logging
 
org.infinispan.client.hotrod.marshall - package org.infinispan.client.hotrod.marshall
 
org.infinispan.commands - package org.infinispan.commands
Commands that operate on the cache, either locally or remotely.
org.infinispan.commands.control - package org.infinispan.commands.control
Commands that control and coordinate certain cache operations, such as rehashing, state transfer and locking.
org.infinispan.commands.module - package org.infinispan.commands.module
 
org.infinispan.commands.read - package org.infinispan.commands.read
Commands that read data from the cache.
org.infinispan.commands.remote - package org.infinispan.commands.remote
Meta-commands that wrap other commands for remote execution.
org.infinispan.commands.remote.recovery - package org.infinispan.commands.remote.recovery
 
org.infinispan.commands.tx - package org.infinispan.commands.tx
Commands that represent transactional lifecycle transitions.
org.infinispan.commands.write - package org.infinispan.commands.write
Commands that alter the state of the cache.
org.infinispan.commons - package org.infinispan.commons
Commons package
org.infinispan.commons.hash - package org.infinispan.commons.hash
 
org.infinispan.config - package org.infinispan.config
Cache configuration beans and parsers.
org.infinispan.config.parsing - package org.infinispan.config.parsing
 
org.infinispan.configuration - package org.infinispan.configuration
 
org.infinispan.configuration.cache - package org.infinispan.configuration.cache
Classes related to eviction.
org.infinispan.configuration.global - package org.infinispan.configuration.global
 
org.infinispan.configuration.parsing - package org.infinispan.configuration.parsing
 
org.infinispan.container - package org.infinispan.container
Data containers which store cache entries.
org.infinispan.container.entries - package org.infinispan.container.entries
Entries which are stored in data containers.
org.infinispan.container.entries.versioned - package org.infinispan.container.entries.versioned
 
org.infinispan.container.versioning - package org.infinispan.container.versioning
 
org.infinispan.context - package org.infinispan.context
Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags.
org.infinispan.context.impl - package org.infinispan.context.impl
This package contains different context implementations, selected dynamically based on the type of invocation.
org.infinispan.demo - package org.infinispan.demo
Classes, programs and applications that help demonstrate how Infinispan can be used.
org.infinispan.demo.distexec - package org.infinispan.demo.distexec
 
org.infinispan.demo.mapreduce - package org.infinispan.demo.mapreduce
 
org.infinispan.demo.nearcache.client - package org.infinispan.demo.nearcache.client
 
org.infinispan.demo.nearcache.server - package org.infinispan.demo.nearcache.server
 
org.infinispan.demos.directory - package org.infinispan.demos.directory
 
org.infinispan.demos.gridfs - package org.infinispan.demos.gridfs
 
org.infinispan.distexec - package org.infinispan.distexec
 
org.infinispan.distexec.mapreduce - package org.infinispan.distexec.mapreduce
 
org.infinispan.distribution - package org.infinispan.distribution
Classes relating to the distributed cache mode.
org.infinispan.distribution.ch - package org.infinispan.distribution.ch
 
org.infinispan.distribution.group - package org.infinispan.distribution.group
Groups allow keys with differeing hash codes to be co-located on the same node.
org.infinispan.ec2demo - package org.infinispan.ec2demo
 
org.infinispan.ec2demo.web - package org.infinispan.ec2demo.web
 
org.infinispan.eviction - package org.infinispan.eviction
Classes related to eviction.
org.infinispan.executors - package org.infinispan.executors
Implementations of different executors used for asynchronous operation.
org.infinispan.factories - package org.infinispan.factories
Factories are internal components used to create other components based on a cache's configuration.
org.infinispan.factories.annotations - package org.infinispan.factories.annotations
Internal annotations to control the lifecycle of cache components.
org.infinispan.factories.components - package org.infinispan.factories.components
 
org.infinispan.factories.scopes - package org.infinispan.factories.scopes
Scopes of components within the lifespan of a CacheManager and its various Caches, and related utilities.
org.infinispan.interceptors - package org.infinispan.interceptors
Infinispan is designed around a set of interceptors around a data container.
org.infinispan.interceptors.base - package org.infinispan.interceptors.base
Base interceptors containing common, reusable behavior.
org.infinispan.interceptors.locking - package org.infinispan.interceptors.locking
 
org.infinispan.io - package org.infinispan.io
Provides Infinispan-specific input and output streams, buffers and related utilities.
org.infinispan.jmx - package org.infinispan.jmx
Helpers that allow easy exposure of attributes and operations via JMX.
org.infinispan.jmx.annotations - package org.infinispan.jmx.annotations
JMX 2.0-like annotations, with no dependencies on JMX 2.0.
org.infinispan.lifecycle - package org.infinispan.lifecycle
Component lifecycle.
org.infinispan.loaders - package org.infinispan.loaders
This package contains loaders and stores, which are used for overflow or persistence.
org.infinispan.loaders.bdbje - package org.infinispan.loaders.bdbje
This package contains a CacheStore implementation based on Oracle's BDBJE storage engine.
org.infinispan.loaders.bdbje.logging - package org.infinispan.loaders.bdbje.logging
 
org.infinispan.loaders.bucket - package org.infinispan.loaders.bucket
Abstract classes that use hashed buckets to store entries.
org.infinispan.loaders.cassandra - package org.infinispan.loaders.cassandra
This package contains a CacheStore implementation based on persisting to Apache Cassandra
org.infinispan.loaders.cassandra.logging - package org.infinispan.loaders.cassandra.logging
 
org.infinispan.loaders.cloud - package org.infinispan.loaders.cloud
This package contains a CacheStore implementation based on JClouds, which in turn is an abstraction layer to store data on cloud infrastructure providers such as Amazon's S3, RackspaceCloud's CloudFiles, Microsoft's Windows Azure Blob Storage API, and others.
org.infinispan.loaders.cloud.logging - package org.infinispan.loaders.cloud.logging
 
org.infinispan.loaders.cluster - package org.infinispan.loaders.cluster
A CacheLoader (not CacheStore) that polls other nodes in the cluster for state.
org.infinispan.loaders.decorators - package org.infinispan.loaders.decorators
This package contains loaders and stores, which are used for overflow or persistence.
org.infinispan.loaders.file - package org.infinispan.loaders.file
Simple filesystem-based CacheStore implementation.
org.infinispan.loaders.jdbc - package org.infinispan.loaders.jdbc
This package contains a CacheStore implementation based on a JDBC database connection.
org.infinispan.loaders.jdbc.binary - package org.infinispan.loaders.jdbc.binary
This JDBC CacheStore implementation is optimized for storing binary (non-String) keys in the cache.
org.infinispan.loaders.jdbc.connectionfactory - package org.infinispan.loaders.jdbc.connectionfactory
Connection factories for use with the JDBC Cache Store.
org.infinispan.loaders.jdbc.logging - package org.infinispan.loaders.jdbc.logging
 
org.infinispan.loaders.jdbc.mixed - package org.infinispan.loaders.jdbc.mixed
This is a delegating CacheStore implementation that delegates either to a binary or String based JDBC cache store depending on the key used.
org.infinispan.loaders.jdbc.stringbased - package org.infinispan.loaders.jdbc.stringbased
This JDBC CacheStore implementation is optimized for storing String keys in the cache.
org.infinispan.loaders.jdbm - package org.infinispan.loaders.jdbm
This package contains a CacheStore implementation based on persisting to JDBM.
org.infinispan.loaders.jdbm.logging - package org.infinispan.loaders.jdbm.logging
 
org.infinispan.loaders.keymappers - package org.infinispan.loaders.keymappers
 
org.infinispan.loaders.modifications - package org.infinispan.loaders.modifications
Modifications that are used to encapsulate cache operations for application to a CacheStore.
org.infinispan.loaders.remote - package org.infinispan.loaders.remote
 
org.infinispan.loaders.remote.logging - package org.infinispan.loaders.remote.logging
 
org.infinispan.lucene - package org.infinispan.lucene
Lucene Directory implementation which stores the index in Infinispan.
org.infinispan.lucene.locking - package org.infinispan.lucene.locking
Lucene's IndexWriter instances are threadsafe but you can have only one open on the index, so when opening an IndexWriter an index-wide lock needs to be acquired.
org.infinispan.lucene.logging - package org.infinispan.lucene.logging
 
org.infinispan.lucene.readlocks - package org.infinispan.lucene.readlocks
Several implementations for a SegmentReadLocker, pick one depending on your use case.
org.infinispan.lucenedemo - package org.infinispan.lucenedemo
 
org.infinispan.manager - package org.infinispan.manager
Cache manager package
org.infinispan.marshall - package org.infinispan.marshall
Infinispan makes use of custom marshalling to serialize and deserialize state wherever possible, rather than falling back to the JDK to do this.
org.infinispan.marshall.exts - package org.infinispan.marshall.exts
Externalizers for various JDK types that are marshalled using the marshalling framework.
org.infinispan.marshall.jboss - package org.infinispan.marshall.jboss
Hooks to bridge Infinispan's marshalling APIs with JBoss Marshalling internals.
org.infinispan.nearcache.cdi - package org.infinispan.nearcache.cdi
 
org.infinispan.nearcache.jms - package org.infinispan.nearcache.jms
 
org.infinispan.notifications - package org.infinispan.notifications
Notifications and eventing for listeners on both the Cache and CacheManager interfaces.
org.infinispan.notifications.cachelistener - package org.infinispan.notifications.cachelistener
Cache-specific notifications and eventing.
org.infinispan.notifications.cachelistener.annotation - package org.infinispan.notifications.cachelistener.annotation
 
org.infinispan.notifications.cachelistener.event - package org.infinispan.notifications.cachelistener.event
 
org.infinispan.notifications.cachemanagerlistener - package org.infinispan.notifications.cachemanagerlistener
CacheManager-specific notifications and eventing.
org.infinispan.notifications.cachemanagerlistener.annotation - package org.infinispan.notifications.cachemanagerlistener.annotation
 
org.infinispan.notifications.cachemanagerlistener.event - package org.infinispan.notifications.cachemanagerlistener.event
 
org.infinispan.query - package org.infinispan.query
 
org.infinispan.query.backend - package org.infinispan.query.backend
 
org.infinispan.query.clustered - package org.infinispan.query.clustered
 
org.infinispan.query.clustered.commandworkers - package org.infinispan.query.clustered.commandworkers
 
org.infinispan.query.impl - package org.infinispan.query.impl
 
org.infinispan.query.logging - package org.infinispan.query.logging
 
org.infinispan.remoting - package org.infinispan.remoting
Remote communication between cache instances.
org.infinispan.remoting.responses - package org.infinispan.remoting.responses
Abstractions of the different response types allowed during RPC.
org.infinispan.remoting.rpc - package org.infinispan.remoting.rpc
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
org.infinispan.remoting.transport - package org.infinispan.remoting.transport
Transports handle the low-level networking, used by the remoting components.
org.infinispan.remoting.transport.jgroups - package org.infinispan.remoting.transport.jgroups
A transport implementation based on JGroups.
org.infinispan.rest.logging - package org.infinispan.rest.logging
 
org.infinispan.rhq - package org.infinispan.rhq
 
org.infinispan.server.core - package org.infinispan.server.core
 
org.infinispan.server.core.logging - package org.infinispan.server.core.logging
 
org.infinispan.server.core.transport - package org.infinispan.server.core.transport
 
org.infinispan.server.hotrod.logging - package org.infinispan.server.hotrod.logging
 
org.infinispan.server.memcached.logging - package org.infinispan.server.memcached.logging
 
org.infinispan.server.websocket - package org.infinispan.server.websocket
 
org.infinispan.server.websocket.handlers - package org.infinispan.server.websocket.handlers
 
org.infinispan.server.websocket.logging - package org.infinispan.server.websocket.logging
 
org.infinispan.spring - package org.infinispan.spring
Spring Infinispan - Shared classes.
org.infinispan.spring.config - package org.infinispan.spring.config
 
org.infinispan.spring.provider - package org.infinispan.spring.provider
Spring Infinispan - An implementation of Spring 3.1's Cache SPI based on JBoss Infinispan.
org.infinispan.spring.support - package org.infinispan.spring.support
 
org.infinispan.spring.support.embedded - package org.infinispan.spring.support.embedded
 
org.infinispan.spring.support.remote - package org.infinispan.spring.support.remote
 
org.infinispan.statetransfer - package org.infinispan.statetransfer
Transfer of state to new caches in a cluster.
org.infinispan.stats - package org.infinispan.stats
Cache statistics.
org.infinispan.tools - package org.infinispan.tools
 
org.infinispan.tools.doclet.config - package org.infinispan.tools.doclet.config
 
org.infinispan.tools.doclet.html - package org.infinispan.tools.doclet.html
 
org.infinispan.tools.doclet.jmx - package org.infinispan.tools.doclet.jmx
 
org.infinispan.tools.rhq - package org.infinispan.tools.rhq
 
org.infinispan.tools.schema - package org.infinispan.tools.schema
 
org.infinispan.transaction - package org.infinispan.transaction
JTA transaction support.
org.infinispan.transaction.lookup - package org.infinispan.transaction.lookup
Interfaces and implementations of lookup classes to locate and/or instantiate JTA TransactionManagers.
org.infinispan.transaction.synchronization - package org.infinispan.transaction.synchronization
 
org.infinispan.transaction.tm - package org.infinispan.transaction.tm
Infinispan's bare-bones internal transaction manager, used for batching calls as well as as a dummy, unit-test-only transaction manager.
org.infinispan.transaction.xa - package org.infinispan.transaction.xa
XA transaction support.
org.infinispan.transaction.xa.recovery - package org.infinispan.transaction.xa.recovery
 
org.infinispan.tree - package org.infinispan.tree
This package contains the TreeCache.
org.infinispan.tree.logging - package org.infinispan.tree.logging
 
org.infinispan.util - package org.infinispan.util
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and collections and containers designed to supplement the JDK-provided containers.
org.infinispan.util.concurrent - package org.infinispan.util.concurrent
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities and containers.
org.infinispan.util.concurrent.jdk7backported - package org.infinispan.util.concurrent.jdk7backported
 
org.infinispan.util.concurrent.jdk8backported - package org.infinispan.util.concurrent.jdk8backported
 
org.infinispan.util.concurrent.locks - package org.infinispan.util.concurrent.locks
Lock and synchronization related classes, tools and utilities.
org.infinispan.util.concurrent.locks.containers - package org.infinispan.util.concurrent.locks.containers
Concurrent lock containers.
org.infinispan.util.logging - package org.infinispan.util.logging
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
org.infinispan.util.stream - package org.infinispan.util.stream
 
originalFetchInMemoryState() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
We want to remember if the user didn't configure fetchInMemoryState for the default cache.
OsgiFileLookup - Class in org.infinispan.util
 
OsgiFileLookup() - Constructor for class org.infinispan.util.OsgiFileLookup
 
overriddenConfigurationElements - Variable in class org.infinispan.config.AbstractConfigurationBean
 
override(OverrideConfigurationVisitor) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
override(Properties) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
OverrideConfigurationVisitor - Class in org.infinispan.config
OverrideConfigurationVisitor breaks down fields of Configuration object to individual components and then compares them for field updates.
OverrideConfigurationVisitor() - Constructor for class org.infinispan.config.OverrideConfigurationVisitor
 
OverrideDefault - Annotation Type in org.infinispan.cdi
Deprecated. The Infinispan CDI integration module now uses the DefaultBean from Solder. The OverrideDefault annotation is not necessary and will be removed in a future release. See DefaultEmbeddedCacheManagerProducer and DefaultEmbeddedCacheConfigurationProducer for more details.
OwnableReentrantLock - Class in org.infinispan.util.concurrent.locks
A lock that supports reentrancy based on owner (and not on current thread).
OwnableReentrantLock() - Constructor for class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
OwnableReentrantPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A per-entry lock container for OwnableReentrantLocks
OwnableReentrantPerEntryLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
OwnableReentrantStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A LockContainer that holds OwnableReentrantLocks.
OwnableReentrantStripedLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
Creates a new LockContainer which uses a certain number of shared locks across all elements that need to be locked.
ownsLock(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
ownsLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
Tests if a give owner owns a lock on a specified object.
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Tests whether a given owner owns a lock of lockType on a particular cache entry.
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 

P

padString(String, int) - Static method in class org.infinispan.util.Util
 
ParameterMetaData - Class in org.infinispan.cdi.interceptor.context.metadata
Contains the metadata for a parameter of a method annotated with A JCACHE annotation.
ParameterMetaData(Class<?>, int, Set<Annotation>) - Constructor for class org.infinispan.cdi.interceptor.context.metadata.ParameterMetaData
 
parse(InputStream, OutputStream, String, ClassLoader) - Method in class org.infinispan.config.parsing.ConfigFilesConvertor
 
parse(String, OutputStream, String, ClassLoader) - Method in class org.infinispan.config.parsing.ConfigFilesConvertor
Writes to the os the infinispan 4.x configuration file resulted by transforming configuration file passed in as inputFile.
parse(InputStream, OutputStream, String, ClassLoader) - Method in class org.infinispan.configuration.parsing.ConfigFilesConvertor
 
parse(String, OutputStream, String, ClassLoader) - Method in class org.infinispan.configuration.parsing.ConfigFilesConvertor
Writes to the os the infinispan 4.x configuration file resulted by transforming configuration file passed in as inputFile.
parse(InputStream) - Method in class org.infinispan.configuration.parsing.Parser
 
parse(List<? extends InputStream>) - Method in class org.infinispan.configuration.parsing.Parser
This will parse all the streams in order overriding at each the global and default cache settings.
parseDefaultConfiguration() - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
parseDefaultConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses the default template configuration.
parseFile(String) - Method in class org.infinispan.configuration.parsing.Parser
 
parseFile(String) - Method in class org.infinispan.ec2demo.Influenza_Parser
 
parseFile(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Parser
 
parseFiles(List<String>) - Method in class org.infinispan.configuration.parsing.Parser
This will parse all the filenames in order overriding at each the global and default cache settings.
parseGlobalConfiguration() - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
parseGlobalConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
GlobalConfiguration would also have a reference to the template default configuration, accessible via org.infinispan.config.GlobalConfiguration#getDefaultConfiguration()

This is typically used to configure a DefaultCacheManager

parseInnerBeanDefinition(Element, ParserContext) - Static method in class org.infinispan.spring.config.InfinispanNamespaceUtils
 
parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.config.InfinispanContainerCacheManagerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.config.InfinispanRemoteCacheManagerBeanDefinitionParser
 
parseNamedConfigurations() - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
parseNamedConfigurations() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses and retrieves configuration overrides for named caches.
parseParameters(String[]) - Method in class org.infinispan.demo.Demo
 
parseProperties(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.Parser
 
parseQuery(String) - Method in class org.infinispan.lucenedemo.DemoActions
Parses a query using the single field as default
Parser - Class in org.infinispan.configuration.parsing
 
Parser(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.Parser
 
parseResponseAndAddToResponseList(Object, Throwable, Map<Address, Response>, boolean, boolean, Address, boolean, boolean) - Method in class org.infinispan.remoting.transport.AbstractTransport
 
ParseUtils - Class in org.infinispan.configuration.parsing
 
participatingInRehash(Address, List<Address>, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
particle(XSParticle) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
passivate(InternalCacheEntry) - Method in interface org.infinispan.eviction.PassivationManager
 
passivate(InternalCacheEntry) - Method in class org.infinispan.eviction.PassivationManagerImpl
 
passivateAll() - Method in interface org.infinispan.eviction.PassivationManager
 
passivateAll() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
passivatedEntries(int, String) - Method in interface org.infinispan.util.logging.Log
 
passivateObject(Object, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
passivatingAllEntries() - Method in interface org.infinispan.util.logging.Log
 
passivation - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
passivation(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
If true, data is only written to the cache store when it is evicted from memory, a phenomenon known as 'passivation'.
passivation(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.LoadersConfig
Deprecated. If true, data is only written to the cache store when it is evicted from memory, a phenomenon known as 'passivation'.
passivation() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
If true, data is only written to the cache store when it is evicted from memory, a phenomenon known as 'passivation'.
passivation(boolean) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
PassivationInterceptor - Class in org.infinispan.interceptors
Writes evicted entries back to the store on the way in through the CacheStore
PassivationInterceptor() - Constructor for class org.infinispan.interceptors.PassivationInterceptor
 
PassivationManager - Interface in org.infinispan.eviction
A passivation manager
PassivationManagerImpl - Class in org.infinispan.eviction
 
PassivationManagerImpl() - Constructor for class org.infinispan.eviction.PassivationManagerImpl
 
passivationWithoutEviction() - Method in interface org.infinispan.util.logging.Log
 
PATH - Static variable in class org.infinispan.util.ClassFinder
 
peek(Object) - Method in interface org.infinispan.container.DataContainer
Retrieves a cache entry in the same way as DataContainer.get(Object)} except that it does not update or reorder any of the internal constructs.
peek(Object) - Method in class org.infinispan.container.DefaultDataContainer
 
peekElements() - Method in class org.infinispan.tree.Fqn
Peeks into the elements that build up this Fqn.
PendingCacheViewChanges - Class in org.infinispan.cacheviews
This class is used on the coordinator to keep track of changes since the last merge.
PendingCacheViewChanges(String) - Constructor for class org.infinispan.cacheviews.PendingCacheViewChanges
 
perform(InvocationContext) - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.control.LockControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
Performs invocation of Callable and returns result
perform(InvocationContext) - Method in class org.infinispan.commands.read.EntrySetCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.KeySetCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.MapReduceCommand
Performs invocation of mapping phase and local reduce phase before returning result to master node
perform(InvocationContext) - Method in class org.infinispan.commands.read.SizeCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.ValuesCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
Invokes a logical "get(key)" on a remote cache and returns results.
perform(InvocationContext) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
Executes commands replicated to the current cache instance by other cache instances.
perform(InvocationContext) - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.RemoveCacheCommand
 
perform(InvocationContext) - Method in interface org.infinispan.commands.ReplicableCommand
Performs the primary function of the command.
perform(InvocationContext) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.tx.PrepareCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Performs an application of delta on a specified entry
perform(InvocationContext) - Method in class org.infinispan.commands.write.ClearCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.EvictCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateCommand
Performs an invalidation on a specified entry
perform(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.PutMapCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.RemoveCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ReplaceCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
Invokes a query on a (remote) cache and returns results (list of keys).
perform(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQCreateEagerQuery
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQCreateLazyQuery
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQGetResultSize
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQKillLazyIterator
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQLazyFetcher
 
performCheckOnKey(Object) - Method in interface org.infinispan.transaction.WriteSkewHelper.KeySpecificLogic
 
performLocalWriteSkewCheck(DataContainer, boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
performStateTransfer() - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
performWriteSkewCheck(DataContainer) - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
performWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, DataContainer, VersionGenerator, TxInvocationContext, WriteSkewHelper.KeySpecificLogic) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
PessimisticLockingInterceptor - Class in org.infinispan.interceptors.locking
Locking interceptor to be used by pessimistic caches.
PessimisticLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
physicalAddress - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
PiApproximationDemo - Class in org.infinispan.demo.distexec
Infinispan distributed executors demo using pi approximation.
PiApproximationDemo(String[]) - Constructor for class org.infinispan.demo.distexec.PiApproximationDemo
 
ping() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
PING_ON_STARTUP - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PING_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PING_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PingOperation - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to the "ping" operation as defined in Hot Rod protocol specification.
PingOperation(Codec, AtomicInteger, Transport) - Constructor for class org.infinispan.client.hotrod.impl.operations.PingOperation
 
PingOperation(Codec, AtomicInteger, Transport, byte[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.PingOperation
 
PingOperation.PingResult - Enum in org.infinispan.client.hotrod.impl.operations
 
PlatformMBeanServerLookup - Class in org.infinispan.jmx
Default implementation for MBeanServerLookup, will return the platform MBean server.
PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
 
poll() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
poll(long, TimeUnit) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
PooledConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Pooled connection factory based on C3P0.
PooledConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
poolProperties - Variable in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
popNDC(boolean) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
popNDC(boolean) - Static method in class org.infinispan.util.logging.BasicLogFactory
 
popNDC(boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
populateCache(JSAPResult) - Method in class org.infinispan.ec2demo.InfluenzaDataLoader
 
position - Variable in class org.infinispan.config.CustomInterceptorConfig
 
position() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
position(InterceptorConfiguration.Position) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Specifies a position, denoted by the InterceptorConfiguration.Position enumeration, where to place the new interceptor.
position() - Method in class org.infinispan.io.ReadableGridFileChannel
 
position(long) - Method in class org.infinispan.io.ReadableGridFileChannel
 
positionKeys - Variable in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
positionValues - Variable in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
possiblyLocked(CacheEntry) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Inspects the entry for signs that it is possibly locked, and hence would need to be unlocked.
possiblyLocked(CacheEntry) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
postingShutdownRequest() - Method in interface org.infinispan.server.core.logging.JavaLog
 
postInstallView(int) - Method in interface org.infinispan.cacheviews.CacheViewListener
Called after the cache view was installed successfully.
postInstallView(int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
postOrderTraverse(TreeNode) - Method in class org.infinispan.tools.schema.AbstractTreeWalker
 
postVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Callback invoked after visiting the specified node n.
postVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
postXMLTableOfContentsCreate(XSOMSchemaTreeWalker, XMLTreeOutputWalker) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Invoked after creation of XML tree table of contents for configuration elements in schema
preInstallView() - Method in interface org.infinispan.cacheviews.CacheViewListener
Called after a node left or after a merge, even if we're not preparing a new view yet we know we'll prepare one soon.
preInstallView() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
preload - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
preload(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
preload(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.LoadersConfig
Deprecated. If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
preload() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
preload(boolean) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
preload() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
preload() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
Performs a preload on the cache based on the cache loader preload configs used when configuring the cache.
preOrderTraverse(TreeNode) - Method in class org.infinispan.tools.schema.AbstractTreeWalker
 
PreparableTransactionRunner - Class in org.infinispan.loaders.bdbje
Adapted version of TransactionRunner, which allows us to prepare a transaction without committing it.

The transaction prepared is accessible via CurrentTransaction.getTransaction()

PreparableTransactionRunner(Environment, int, TransactionConfig) - Constructor for class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Delegates to the superclass and caches a current reference to CurrentTransaction.
PreparableTransactionRunner(Environment) - Constructor for class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Delegates to the superclass and caches a current reference to CurrentTransaction.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.AbstractCacheStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Issues a prepare call with a set of modifications to be applied to the cache store
prepare(List<? extends Modification>, GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Looks up the SleepyCat transaction associated with tx.
prepare(TransactionWorker) - Method in class org.infinispan.loaders.bdbje.PreparableTransactionRunner
Same behaviour as run, except that the transaction is not committed on success.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in interface org.infinispan.loaders.CacheStore
Issues a prepare call with a set of modifications to be applied to the cache store
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
prepare(LocalTransaction) - Method in class org.infinispan.transaction.TransactionCoordinator
 
prepare(LocalTransaction, boolean) - Method in class org.infinispan.transaction.TransactionCoordinator
 
prepare(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
This can be call for any transaction object.
prepareCacheLoader(TxInvocationContext, GlobalTransaction, TxInvocationContext, boolean) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
PrepareCommand - Class in org.infinispan.commands.tx
Command corresponding to the 1st phase of 2PC.
PrepareCommand(String, GlobalTransaction, boolean, WriteCommand...) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(String, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(String) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
prepared - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in interface org.infinispan.util.logging.Log
 
PreparedTxIterator - Class in org.infinispan.transaction.xa.recovery
Default implementation for RecoveryIterator.
PreparedTxIterator() - Constructor for class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
prepareOnAffectedNodes(TxInvocationContext, PrepareCommand, Collection<Address>, boolean) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
prepareOnAffectedNodes(TxInvocationContext, PrepareCommand, Collection<Address>, boolean) - Method in class org.infinispan.interceptors.VersionedDistributionInterceptor
 
prepareRenderer(TableCellRenderer, int, int) - Method in class org.infinispan.demo.InfinispanDemo.AlternateColorTable
Shades alternate rows in different colors.
prepareView(CacheView) - Method in class org.infinispan.cacheviews.CacheViewInfo
Update the pending view.
prepareView(CacheView, CacheView) - Method in interface org.infinispan.cacheviews.CacheViewListener
Called after preparing a cache view.
prepareView(CacheView, CacheView) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
prepareViewIdMismatch(CacheView, CacheView) - Method in interface org.infinispan.util.logging.Log
 
prepareWiringCache() - Method in class org.infinispan.factories.ComponentRegistry
Invoked last after all services are wired
PrePostProcessingCommandInterceptor - Class in org.infinispan.interceptors.base
This interceptor adds pre and post processing to each visitXXX() method.
PrePostProcessingCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
prettyPrintTime(long, TimeUnit) - Static method in class org.infinispan.util.Util
 
prettyPrintTime(long) - Static method in class org.infinispan.util.Util
Prints a time for display
previous() - Method in class org.infinispan.query.clustered.DistributedIterator
 
previous() - Method in class org.infinispan.query.impl.EagerIterator
Returns the previous element in the list.
previous() - Method in class org.infinispan.query.impl.LazyIterator
 
previousIndex() - Method in class org.infinispan.query.clustered.DistributedIterator
 
previousIndex() - Method in class org.infinispan.query.impl.EagerIterator
Returns the index of the element that would be returned by a subsequent call to previous.
previousIndex() - Method in class org.infinispan.query.impl.LazyIterator
 
preVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Callback invoked prior to visiting the specified node n.
preVisitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
preXMLTableOfContentsCreate(XSOMSchemaTreeWalker, XMLTreeOutputWalker) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
Invoked prior to creation of XML tree table of contents for configuration elements in schema
preXMLTableOfContentsCreate(XSOMSchemaTreeWalker, XMLTreeOutputWalker) - Method in class org.infinispan.tools.doclet.config.ConfigHtmlGenerator
 
primaryLocation(Object) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
primaryLocation(Object) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
primaryLocation(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Should be equivalent to return the first element of ConsistentHash.locate(Object, int).
printArray(byte[], boolean) - Static method in class org.infinispan.util.Util
 
printDebugStats() - Method in class org.infinispan.util.FastCopyHashMap
 
printFullVersionInformation() - Static method in class org.infinispan.Version
Prints full version information to the standard output.
printLicense() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
prints terms of use for Berkeley DB JE
printLockInfo() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Prints lock information for all locks.
printLockInfo() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
printTree(TreeCache<?, ?>, boolean) - Static method in class org.infinispan.tree.TreeStructureSupport
Visual representation of a tree
printVersion() - Static method in class org.infinispan.Version
Returns version information as a string.
printVersionId(byte[], int) - Static method in class org.infinispan.Version
 
problemApplyingStateForKey(String, Object) - Method in interface org.infinispan.util.logging.Log
 
problemClosingChannel(Exception) - Method in interface org.infinispan.util.logging.Log
 
problemPurgingExpired(Exception) - Method in interface org.infinispan.util.logging.Log
 
problemsCreatingDirectory(File) - Method in interface org.infinispan.util.logging.Log
 
problemsPurging(Exception) - Method in interface org.infinispan.loaders.cloud.logging.Log
 
problemsPurgingFile(File, CacheLoaderException) - Method in interface org.infinispan.util.logging.Log
 
problemsRemovingFile(File) - Method in interface org.infinispan.util.logging.Log
 
problemsUnregisteringMBeans(Exception) - Method in interface org.infinispan.util.logging.Log
 
processEviction() - Method in interface org.infinispan.eviction.EvictionManager
Processes the eviction event queue.
processEviction() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
processFile(String, ProteinCache) - Method in class org.infinispan.ec2demo.Influenza_Parser
 
processFile(String, ProteinCache) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Parser
 
processVisitableCommand(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
PROJECT_NAME - Static variable in class org.infinispan.Version
 
projection(String...) - Method in interface org.infinispan.query.CacheQuery
Defines the Lucene field names projected and returned in a query result Each field is converted back to it's object representation, an Object[] being returned for each "row"

A projectable field must be stored in the Lucene index and use a org.hibernate.search.bridge.TwoWayFieldBridge Unless notified in their JavaDoc, all built-in bridges are two-way.

projection(String...) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
properties - Variable in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
properties - Variable in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
properties - Variable in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
properties() - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
properties - Variable in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
properties - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
properties() - Method in class org.infinispan.configuration.AbstractTypedPropertiesConfiguration
 
properties() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
These properties are passed directly to the embedded Hibernate Search engine, so for the complete and up to date documentation about available properties refer to the Hibernate Search reference of the version you're using with Infinispan Query.
properties() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
properties() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
properties - Variable in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
propertyCouldNotBeReplaced(String) - Method in interface org.infinispan.util.logging.Log
 
props - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
PropsKeyedObjectPoolFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
PropsKeyedObjectPoolFactory(KeyedPoolableObjectFactory, Properties) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.PropsKeyedObjectPoolFactory
 
ProteinCache - Class in org.infinispan.ec2demo
 
ProteinCache(CacheBuilder) - Constructor for class org.infinispan.ec2demo.ProteinCache
 
PROTOCOL_VERSION - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PROTOCOL_VERSION_10 - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PROTOCOL_VERSION_11 - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
Proxies - Class in org.infinispan.util
Proxies is a collection of useful dynamic profixes.
Proxies() - Constructor for class org.infinispan.util.Proxies
 
purge() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
purge() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
purgeExpired() - Method in interface org.infinispan.container.DataContainer
Purges entries that have passed their expiry time
purgeExpired() - Method in class org.infinispan.container.DefaultDataContainer
 
purgeExpired() - Method in class org.infinispan.loaders.AbstractCacheStore
 
purgeExpired() - Method in interface org.infinispan.loaders.CacheStore
Purges expired entries from the store.
purgeExpired() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
purgeExpired() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
PurgeExpired - Class in org.infinispan.loaders.modifications
 
PurgeExpired() - Constructor for class org.infinispan.loaders.modifications.PurgeExpired
 
purgeIfNecessary() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.AbstractCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Iterate through StoredMap.entrySet() and remove, if expired.
purgeInternal() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
Purge expired entries.
purgeInternal() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.file.FileCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
purgeInternal() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Purge expired entries.
purgeInternal() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
purgeOnStartup() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
If true, purges this cache store when it starts up.
purgeOnStartup(boolean) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
purgeOnStartup(boolean) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
If true, purges this cache store when it starts up.
purgeOnStartup - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
purgeOnStartup(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, purges this cache store when it starts up.
purgeOnStartup(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
purgeOnStartup(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
purgeOnStartup(Boolean) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
purgerService - Variable in class org.infinispan.loaders.AbstractCacheStore
 
purgerThreads() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
The number of threads to use when purging asynchronously.
purgerThreads(int) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
purgerThreads(int) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
The number of threads to use when purging asynchronously.
purgerThreads - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
purgerThreads(Integer) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
purgerThreads(Integer) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
purgerThreads(Integer) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
purgeStaleEntries() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Removes any stale entries whose keys have been finalized.
purgeSynchronously() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
If true, CacheStore#purgeExpired() call will be done synchronously
purgeSynchronously(boolean) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
purgeSynchronously(boolean) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
If true, CacheStore#purgeExpired() call will be done synchronously
purgeSynchronously - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
purgeSynchronously(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, CacheStore#purgeExpired() call will be done synchronously
purgeSynchronously(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
 
purgeSynchronously(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
purgeSynchronously(Boolean) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
pushCacheValue(String, Cache<Object, Object>, ChannelHandlerContext) - Static method in class org.infinispan.server.websocket.ChannelUtils
Push a cache entry value out onto the websocket channel (to the browser).
pushNDC(String, boolean) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.BasicLogFactory
 
pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
pushPartialState(Collection<Address>, Collection<InternalCacheEntry>, Collection<LockInfo>) - Method in class org.infinispan.statetransfer.BaseStateTransferTask
 
pushState(Cache<Object, Object>) - Method in class org.infinispan.loaders.decorators.SingletonStore
Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
pushStateTimeout() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
If pushStateWhenCoordinator is true, this property sets the maximum number of milliseconds that the process of pushing the in-memory state to the underlying cache loader should take.
pushStateTimeout(long) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
If pushStateWhenCoordinator is true, this property sets the maximum number of milliseconds that the process of pushing the in-memory state to the underlying cache loader should take.
pushStateTimeout - Variable in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
pushStateTimeout(Long) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
If pushStateWhenCoordinator is true, this property sets the maximum number of milliseconds that the process of pushing the in-memory state to the underlying cache loader should take.
pushStateToNode(NotifyingNotifiableFuture<Object>, int, Collection<Address>, Collection<InternalCacheEntry>, Collection<LockInfo>) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
pushStateWhenCoordinator() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
If true, when a node becomes the coordinator, it will transfer in-memory state to the underlying cache store.
pushStateWhenCoordinator(boolean) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
If true, when a node becomes the coordinator, it will transfer in-memory state to the underlying cache store.
pushStateWhenCoordinator - Variable in class org.infinispan.loaders.decorators.SingletonStoreConfig
 
pushStateWhenCoordinator(Boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
If true, when a node becomes the coordinator, it will transfer in-memory state to the underlying cache store.
put(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
put(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of Map.put(Object, Object), which takes in lifespan parameters.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of Map.put(Object, Object), which takes in lifespan parameters.
put(K, V) - Method in class org.infinispan.atomic.AtomicHashMap
 
put(K, V) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
put(K, V) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
put(K, V) - Method in class org.infinispan.CacheSupport
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
put(byte[], byte[], int, int, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
put(Object, Object, EntryVersion, long, long) - Method in interface org.infinispan.container.DataContainer
Puts an entry in the cache along with a lifespan and a maxIdle time
put(Object, Object, EntryVersion, long, long) - Method in class org.infinispan.container.DefaultDataContainer
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
put(K, V) - Method in class org.infinispan.DecoratedCache
 
put(UUID, DocumentExtractor) - Method in class org.infinispan.query.clustered.QueryBox
Register a query (DocumentExtractor), so we can lazily load the results.
put(Object, Object) - Method in class org.infinispan.spring.provider.SpringCache
 
put(K, V) - Method in interface org.infinispan.tree.Node
Associates the specified value with the specified key for this node.
put(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
put(K, V) - Method in class org.infinispan.tree.NodeImpl
 
put(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
put(Fqn, K, V) - Method in interface org.infinispan.tree.TreeCache
Associates the specified value with the specified key for a Node in this cache.
put(Fqn, K, V, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, K, V) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
put(String, K, V, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(Fqn, Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.TreeCache
Copies all of the mappings from the specified map to a Node.
put(Fqn, Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
put(String, Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
put(String, K, V) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, K, V, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(String, Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, K, V) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(Fqn, K, V, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
put(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Maps the specified key to the specified value in this table.
put(K, V) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Maps the specified key to the specified value in this table.
put(K, V) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Maps the specified key to the specified value in this table.
put(K, V) - Method in class org.infinispan.util.FastCopyHashMap
 
PUT_IF_ABSENT_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_IF_ABSENT_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of Map.putAll(Map), which takes in lifespan parameters.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of Map.putAll(Map), which takes in lifespan parameters.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.AtomicHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.DecoratedCache
 
putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.Node
Copies all of the mappings from the specified map to this node's map.
putAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.Node
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.NodeImpl
 
putAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.util.FastCopyHashMap
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of Map.putAll(Map).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.putAll(Map, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.putAll(Map, long, TimeUnit, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.DecoratedCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAsync(K, V) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of Map.put(Object, Object).
putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.put(Object, Object, long, TimeUnit) .
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.put(Object, Object, long, TimeUnit, long, TimeUnit).
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAsync(K, V) - Method in class org.infinispan.CacheSupport
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAsync(K, V) - Method in class org.infinispan.DecoratedCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putForExternalRead(K, V, EnumSet<Flag>, ClassLoader) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
putForExternalRead(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putForExternalRead(K, V) - Method in interface org.infinispan.Cache
Under special operating behavior, associates the value with the specified key.
putForExternalRead(K, V) - Method in class org.infinispan.CacheImpl
 
putForExternalRead(K, V) - Method in class org.infinispan.DecoratedCache
 
PutHandler - Class in org.infinispan.server.websocket.handlers
Cache "get" operation handler.
PutHandler() - Constructor for class org.infinispan.server.websocket.handlers.PutHandler
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.CacheSupport
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putIfAbsent(byte[], byte[], int, int, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putIfAbsent(K, V) - Method in class org.infinispan.DecoratedCache
 
putIfAbsent(K, V) - Method in interface org.infinispan.tree.Node
If the specified key is not already associated with a value, associate it with the given value, and returns the Object (if any) that occupied the space, or null.
putIfAbsent(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
putIfAbsent(K, V) - Method in class org.infinispan.tree.NodeImpl
 
putIfAbsent(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
putIfAbsent(K, V) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
putIfAbsent(K, V) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
putIfAbsentAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of ConcurrentMap.putIfAbsent(Object, Object).
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.putIfAbsent(Object, Object, long, TimeUnit) .
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit).
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.DecoratedCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
PutIfAbsentOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "putIfAbsent" operation as described in Hot Rod protocol specification.
PutIfAbsentOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.PutIfAbsentOperation
 
PutKeyValueCommand - Class in org.infinispan.commands.write
Implements functionality defined by Map.put(Object, Object)
PutKeyValueCommand() - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
PutKeyValueCommand(Object, Object, boolean, CacheNotifier, long, long, Set<Flag>) - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.ImmutableContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.LocalTransaction
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.RemoteTransaction
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.context.EntryLookup
Puts an entry in the registry of looked up entries in the current scope.
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.ImmutableContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.LocalTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.RemoteTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
PutMapCommand - Class in org.infinispan.commands.write
 
PutMapCommand() - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutMapCommand(Map<?, ?>, CacheNotifier, long, long, Set<Flag>) - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutOperation<K,V> - Class in org.infinispan.atomic
An atomic put operation.
PutOperation() - Constructor for class org.infinispan.atomic.PutOperation
 
PutOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "put" as defined by Hot Rod protocol specification.
PutOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.PutOperation
 
PutOperation.Externalizer - Class in org.infinispan.atomic
 
PutOperation.Externalizer() - Constructor for class org.infinispan.atomic.PutOperation.Externalizer
 
putReferencedObject(int, Object) - Method in class org.infinispan.marshall.UnmarshalledReferences
Adds a referenced object to the list of references

Q

queriedAttributeNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
query - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
QueryBox - Class in org.infinispan.query.clustered
Each node in the cluster has a QueryBox instance.
QueryBox() - Constructor for class org.infinispan.query.clustered.QueryBox
 
QueryExtractorUtil - Class in org.infinispan.query.clustered.commandworkers
QueryExtractorUtil.
QueryInterceptor - Class in org.infinispan.query.backend
This interceptor will be created when the System Property "infinispan.query.indexLocalOnly" is "false"

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

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

QueryMetadataFileFinder - Class in org.infinispan.query
 
QueryMetadataFileFinder() - Constructor for class org.infinispan.query.QueryMetadataFileFinder
 
QueryModuleCommandExtensions - Class in org.infinispan.query
 
QueryModuleCommandExtensions() - Constructor for class org.infinispan.query.QueryModuleCommandExtensions
 
QueryResponse - Class in org.infinispan.query.clustered
QueryResponse.
QueryResponse(Object) - Constructor for class org.infinispan.query.clustered.QueryResponse
 
QueryResponse(int) - Constructor for class org.infinispan.query.clustered.QueryResponse
 
QueryResponse(TopDocs, UUID, int) - Constructor for class org.infinispan.query.clustered.QueryResponse
 

R

rackId(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. The id of the rack where this node runs.
rackId - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
rackId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
rackId() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
rackId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
The id of the rack where this node runs.
randomCacheModeSynonymsDeprecated(String, String, List<String>) - Method in interface org.infinispan.util.logging.Log
 
randomClusterMembers(List<Address>, int) - Method in class org.infinispan.distexec.DefaultExecutorService
 
raw - Variable in class org.infinispan.marshall.MarshalledValue
 
read(AsyncConfiguration) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
read(AsyncLoaderConfiguration) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
 
read(ClusteringConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
read(Configuration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
read(CustomInterceptorsConfiguration) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
read(DataContainerConfiguration) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
 
read(DeadlockDetectionConfiguration) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
 
read(EvictionConfiguration) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
 
read(ExpirationConfiguration) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
read(FileCacheStoreConfiguration) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
read(GroupsConfiguration) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
read(HashConfiguration) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
read(IndexingConfiguration) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
read(InterceptorConfiguration) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
read(InvocationBatchingConfiguration) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
read(JMXStatisticsConfiguration) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
read(L1Configuration) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
read(LoaderConfiguration) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
 
read(LoadersConfiguration) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
read(LockingConfiguration) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
read(RecoveryConfiguration) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
read(SingletonStoreConfiguration) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
 
read(StateTransferConfiguration) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
read(StoreAsBinaryConfiguration) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
 
read(SyncConfiguration) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
 
read(TransactionConfiguration) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
read(UnsafeConfiguration) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
read(VersioningConfiguration) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
read(GlobalConfiguration) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
read(ScheduledExecutorFactoryConfiguration) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
read() - Method in class org.infinispan.io.GridInputStream
 
read(byte[]) - Method in class org.infinispan.io.GridInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.GridInputStream
 
read(ByteBuffer) - Method in class org.infinispan.io.ReadableGridFileChannel
 
read() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read() - Method in class org.infinispan.util.Base64.InputStream
Reads enough of the input stream to convert to/from Base64 and returns the next byte.
read(byte[], int, int) - Method in class org.infinispan.util.Base64.InputStream
Calls Base64.InputStream.read() repeatedly until the end of stream is reached or len bytes are read.
read4ByteInt() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
read4ByteInt() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
ReadableGridFileChannel - Class in org.infinispan.io
 
readArray() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readArray() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
reads an vint which is size; then an array having that size.
readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readBooleanAttribute(Element, String, String, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Retrieves the boolean value of a given attribute for the first encountered instance of elementName
readBooleanAttributeElement(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Read an element which contains only a single boolean attribute.
readBooleanContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readBooleanContents(Element, String, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readByte() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readByte() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readByte() - Method in class org.infinispan.lucene.InfinispanIndexInput
 
readByte() - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
readByteArray(int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readByteArray(int) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readBytes(byte[], int, int) - Method in class org.infinispan.lucene.InfinispanIndexInput
 
readBytes(byte[], int, int) - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
ReadCommittedEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
ReadCommittedEntry() - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry(Object, Object, EntryVersion, long) - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry.Flags - Enum in org.infinispan.container.entries
 
readDouble() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readEnvironmentProperties() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
readExternal(ObjectInput) - Method in class org.infinispan.io.GridFile.Metadata
 
readExternal(Object, ObjectInput) - Method in class org.infinispan.marshall.jboss.JBossExternalizerAdapter
 
readExternal(ObjectInput) - Method in class org.infinispan.nearcache.cdi.Address
 
readExternal(ObjectInput) - Method in class org.infinispan.util.ImmutableListCopy
See ImmutableListCopy.writeExternal(java.io.ObjectOutput) for serialization format
readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readHeader(Transport, HeaderParams) - Method in interface org.infinispan.client.hotrod.impl.protocol.Codec
Reads a response header from the transport and returns the status of the response.
readHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
readHeaderAndValidate(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
Magic | Message Id | Op code | Status | Topology Change Marker
readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readKeys - Variable in class org.infinispan.transaction.LocalTransaction
 
readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLong() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readLong() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readManagedAttributeAlreadyPresent(Method) - Method in interface org.infinispan.util.logging.Log
 
readMetadata(URL) - Static method in class org.infinispan.factories.components.ComponentMetadataRepo
 
readNewTopologyAndHash(Transport, AtomicInteger) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.cacheviews.CacheView.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commons.hash.MurmurHash2.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commons.hash.MurmurHash2Compat.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.context.Flag.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.UnionConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.RemoteTransactionLogDetails.Externalizer
 
readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject(ObjectInput) - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
readObject(ObjectInput) - Method in interface org.infinispan.marshall.Externalizer
Read an instance from the stream.
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.LinkedListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.SetExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.SingletonListExternalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.statetransfer.LockInfo.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.tree.Fqn.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.tree.NodeKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
ReadOnlyDataContainerBackedKeySet - Class in org.infinispan.util
A Set view of keys in a data container, which is read-only and has efficient contains(), unlike some data container ley sets.
ReadOnlyDataContainerBackedKeySet(DataContainer) - Constructor for class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
ReadOnlyStore - Class in org.infinispan.loaders.decorators
A decorator that makes the underlying store a CacheLoader, i.e., suppressing all write methods.
ReadOnlyStore(CacheStore) - Constructor for class org.infinispan.loaders.decorators.ReadOnlyStore
 
readParameters(ObjectInput) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
readPropertiesContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of a named sub element within a given element, and attempts to parse the contents as a Java properties file.
readPropertiesContents(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readString() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readString() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readStringAttributeElement(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Read an element which contains only a single string attribute.
readStringContents(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Reads the contents of the first occurrence of elementName under the given element, trimming results of whitespace.
readUnsignedByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUnsignedInt(ObjectInput) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedInt(InputStream) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedInt(ByteBuffer) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedInt(byte[], int) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(ObjectInput) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(InputStream) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedLong(ByteBuffer) - Static method in class org.infinispan.io.UnsignedNumeric
 
readUnsignedLong(byte[], int) - Static method in class org.infinispan.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedShort() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readUnsignedShort() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readUnsignedShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUTF() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readVersionsFromResponse(Response, CacheTransaction) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
readVInt() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readVInt() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readVLong() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readVLong() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
reaperEnabled - Variable in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
reaperEnabled(Boolean) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
reaperEnabled(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.ExpirationConfig
Deprecated. Sets whether the background reaper thread is enabled to test entries for expiration.
reaperEnabled() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
Determines whether the background reaper thread is enabled to test entries for expiration.
reaperEnabled(boolean) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Enable the background reaper to test entries for expiration.
recalculateMinViewIdIfNeeded(CacheTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
recalculateMinViewIdOnTopologyChange(ViewChangedEvent) - Method in class org.infinispan.transaction.TransactionTable
 
receivedClusterView(View) - Method in interface org.infinispan.util.logging.Log
 
receivedMergedView(View) - Method in interface org.infinispan.util.logging.Log
 
ReclosableLatch - Class in org.infinispan.util.concurrent
A thread gat, that uses an AbstractQueuedSynchronizer.
ReclosableLatch() - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
ReclosableLatch(boolean) - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
recordSize(int) - Method in class org.infinispan.marshall.AdaptiveBufferSizePredictor
 
recordSize(int) - Method in interface org.infinispan.marshall.BufferSizePredictor
Record the size of the of data in the last buffer used.
recover(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
RecoverableTransactionIdentifier - Interface in org.infinispan.transaction.xa.recovery
Interface that adds recovery required information to a GlobalTransaction.
recoveredViews(Collection<Address>, Collection<Address>) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
Signal a merge
recovery - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
recovery() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
recovery() - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. This method allows configuration of the transaction recovery cache.
recovery() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
recovery() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
This method allows configuration of the transaction recovery cache.
recovery() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
This method allows configuration of the transaction recovery cache.
recovery() - Method in interface org.infinispan.configuration.cache.TransactionConfigurationChildBuilder
 
RecoveryAdminOperations - Class in org.infinispan.transaction.xa.recovery
Admin utility class for allowing management of in-doubt transactions (e.g.
RecoveryAdminOperations() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
RecoveryAwareDldGlobalTransaction - Class in org.infinispan.transaction.xa.recovery
DldGlobalTransaction that also holds xid information, required for recovery.
RecoveryAwareDldGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
RecoveryAwareDldGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
RecoveryAwareDldGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa.recovery
 
RecoveryAwareDldGlobalTransaction.Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
RecoveryAwareGlobalTransaction - Class in org.infinispan.transaction.xa.recovery
GlobalTransaction that also holds xid information, required for recovery.
RecoveryAwareGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
RecoveryAwareGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
RecoveryAwareGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa.recovery
 
RecoveryAwareGlobalTransaction.Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
RecoveryAwareLocalTransaction - Class in org.infinispan.transaction.xa.recovery
Extends LocalXaTransaction and adds recovery related information.
RecoveryAwareLocalTransaction(Transaction, GlobalTransaction, boolean, int) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
 
RecoveryAwareRemoteTransaction - Class in org.infinispan.transaction.xa.recovery
Extends RemoteTransaction and adds recovery related information and functionality.
RecoveryAwareRemoteTransaction(WriteCommand[], GlobalTransaction, int) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
RecoveryAwareRemoteTransaction(GlobalTransaction, int) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
RecoveryAwareTransaction - Interface in org.infinispan.transaction.xa.recovery
Base interface for transactions that are holders of recovery information.
RecoveryAwareTransactionTable - Class in org.infinispan.transaction.xa.recovery
Transaction table that delegates prepared transaction's management to the RecoveryManager.
RecoveryAwareTransactionTable() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
RecoveryCommand - Class in org.infinispan.commands.remote.recovery
Base class for recovery-related rpc-commands.
RecoveryCommand(String) - Constructor for class org.infinispan.commands.remote.recovery.RecoveryCommand
 
RecoveryConfiguration - Class in org.infinispan.configuration.cache
Defines recovery configuration for the cache.
RecoveryConfigurationBuilder - Class in org.infinispan.configuration.cache
Defines recovery configuration for the cache.
recoveryIgnored() - Method in interface org.infinispan.util.logging.Log
 
recoveryInfoCacheName(String) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
recoveryInfoCacheName(String) - Method in interface org.infinispan.config.FluentConfiguration.RecoveryConfig
Deprecated. Sets the name of the cache where recovery related information is held.
recoveryInfoCacheName() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
Sets the name of the cache where recovery related information is held.
recoveryInfoCacheName(String) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Sets the name of the cache where recovery related information is held.
RecoveryInfoKey - Class in org.infinispan.transaction.xa.recovery
This makes sure that only xids pertaining to a certain cache are being returned when needed.
RecoveryInfoKey(Xid, String) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
recoveryManager - Variable in class org.infinispan.commands.remote.recovery.RecoveryCommand
 
recoveryManager - Variable in class org.infinispan.commands.tx.PrepareCommand
 
RecoveryManager - Interface in org.infinispan.transaction.xa.recovery
RecoveryManager is the component responsible with managing recovery related information and the functionality associated with it.
RecoveryManager.InDoubtTxInfo - Interface in org.infinispan.transaction.xa.recovery
An object describing in doubt transaction's state.
RecoveryManager.RecoveryIterator - Interface in org.infinispan.transaction.xa.recovery
Stateful structure allowing prepared-tx retrieval in a batch-oriented manner, as required by XAResource.recover(int).
RecoveryManagerFactory - Class in org.infinispan.factories
Factory for RecoveryManager.
RecoveryManagerFactory() - Constructor for class org.infinispan.factories.RecoveryManagerFactory
 
RecoveryManagerImpl - Class in org.infinispan.transaction.xa.recovery
Default implementation for RecoveryManager
RecoveryManagerImpl(ConcurrentMap<RecoveryInfoKey, RecoveryAwareRemoteTransaction>, String) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
reduce(String, Iterator<Integer>) - Method in class org.infinispan.demo.mapreduce.WordCountReducer
 
reduce(KOut, Iterator<VOut>) - Method in interface org.infinispan.distexec.mapreduce.Reducer
Combines/reduces all intermediate values for a particular intermediate key to a single value.
reducedWith(Reducer<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Specifies Reducer to use for this MapReduceTask
Reducer<KOut,VOut> - Interface in org.infinispan.distexec.mapreduce
Reduces intermediate key/value results from map phase of MapReduceTask.
ReentrantPerEntryLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A per-entry lock container for ReentrantLocks
ReentrantPerEntryLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
ReentrantStripedLockContainer - Class in org.infinispan.util.concurrent.locks.containers
A LockContainer that holds ReentrantLocks
ReentrantStripedLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
Creates a new LockContainer which uses a certain number of shared locks across all elements that need to be locked.
ReflectionUtil - Class in org.infinispan.util
Basic reflection utilities to enhance what the JDK provides.
ReflectionUtil() - Constructor for class org.infinispan.util.ReflectionUtil
 
registerComponent(Object, Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Registers a component in the registry under the given type, and injects any dependencies needed.
registerComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerComponent(Object, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerComponentInternal(Object, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerComponentInternal(Object, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
registerConfiguration(String, Configuration) - Method in interface org.infinispan.config.ConfigurationRegistry
Register the given configuration under the given name.
registerInDoubtTransaction(RecoveryAwareRemoteTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
registeringQueryInterceptor() - Method in interface org.infinispan.query.logging.Log
 
registerKeyTransformer(Class<?>, Class<? extends Transformer>) - Method in class org.infinispan.query.backend.QueryInterceptor
 
registerKeyTransformer(Class<?>, Class<? extends Transformer>) - Method in interface org.infinispan.query.SearchManager
Registers a Transformer for the supplied key class.
registerLockedKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
registerMBean(ResourceDMBean, ObjectName, MBeanServer) - Static method in class org.infinispan.jmx.JmxUtil
Register the given dynamic JMX MBean.
registerMBeans(Set<AbstractComponentRegistry.Component>, GlobalConfiguration) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
registerMBeans() - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Performs the MBean registration.
registerNamedComponentRegistry(ComponentRegistry, String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
registerNonVolatileComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerNonVolatileComponent(Object, Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
registerNullComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
registers a special "null" component that has no dependencies.
registerObservers(Set<Annotation>, Listenable) - Method in class org.infinispan.cdi.event.cache.CacheEventBridge
 
registerObservers(Set<Annotation>, String, Listenable) - Method in class org.infinispan.cdi.event.cachemanager.CacheManagerEventBridge
 
registerSynchronization(Synchronization) - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Registers the synchronization passed in as a parameter with the ongoing transaction.
registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
Register a Synchronization callback with this transaction.
registerTransformer(Class<?>, Class<? extends Transformer>) - Method in class org.infinispan.query.backend.KeyTransformationHandler
Registers a Transformer for the supplied key class.
rehashCommandReceivedOnNonDistributedCache() - Method in interface org.infinispan.util.logging.Log
 
rehashDisabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated. Use StateTransferConfigurationBuilder.fetchInMemoryState(boolean) instead.
rehashEnabled - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
rehashEnabled(Boolean) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
rehashEnabled(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated. If false, no rebalancing or rehashing will take place when a new node joins the cluster or a node leaves
rehashEnabled() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated. Use StateTransferConfiguration.fetchInMemoryState() instead.
rehashEnabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated. Use StateTransferConfigurationBuilder.fetchInMemoryState(boolean) instead.
rehashEnabled(boolean) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated. Use StateTransferConfigurationBuilder.fetchInMemoryState(boolean) instead.
rehashRpcTimeout - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
rehashRpcTimeout(Long) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
rehashRpcTimeout(Long) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated. Rehashing timeout
rehashRpcTimeout() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated. Use StateTransferConfiguration.timeout() instead.
rehashRpcTimeout(long) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated. Use StateTransferConfigurationBuilder.timeout(long) instead.
rehashWait - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.  
rehashWait(Long) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
rehashWait(Long) - Method in interface org.infinispan.config.FluentConfiguration.HashConfig
Deprecated.  
rehashWait() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated. Use StateTransferConfiguration.timeout() instead.
rehashWait(long) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated. No longer used.
reincarnate() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
reincarnate() - Method in interface org.infinispan.container.entries.InternalCacheEntry
"Reincarnates" an entry.
reincarnate() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
release() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
release() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
releaseAllLocks(List<Object>) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases locks on all keys passed in.
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Destroys a connection.
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
releaseForCommand(InvocationContext, WriteCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseForCommand(TxInvocationContext, PrepareCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseForCommand(TxInvocationContext, CommitCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseForCommand(TxInvocationContext, RollbackCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseForCommand(TxInvocationContext, LockControlCommand) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseForCommand(InvocationContext, WriteCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
releaseForCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
releaseForCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
releaseForCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
releaseForCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
releaseGlobalLock(boolean) - Method in class org.infinispan.loaders.LockSupportCacheStore
Based on the supplied param, releases a global read(false) or write (true) lock.
releaseGlobalLock(boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
releaseLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
releaseLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractStripedLockContainer
 
releaseLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
Release lock on the given key.
releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases a lock the caller may be holding.
releaseLocksForCompletedTransaction(LocalTransaction) - Method in class org.infinispan.transaction.AbstractEnlistmentAdapter
 
releaseTransport(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
releaseTransport(Transport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
releaseTransport(Transport) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
remap(K, V) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.RemappingFunction
Returns a new value given a key and its current value.
Remote - Annotation Type in org.infinispan.cdi
Qualifier used to specify which remote cache will be injected.
REMOTE_TX_LOG_DETAILS - Static variable in interface org.infinispan.marshall.Ids
 
RemoteCache<K,V> - Interface in org.infinispan.client.hotrod
Provides remote reference to a Hot Rod server/cluster.
RemoteCacheImpl<K,V> - Class in org.infinispan.client.hotrod.impl
 
RemoteCacheImpl(RemoteCacheManager, String) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
RemoteCacheManager - Class in org.infinispan.client.hotrod
Factory for RemoteCaches.
RemoteCacheManager(Marshaller, Properties, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Builds a remote cache manager that relies on the provided Marshaller for marshalling keys and values to be send over to the remote Infinispan cluster.
RemoteCacheManager(Marshaller, Properties, boolean, ClassLoader, ExecutorFactory) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Builds a remote cache manager that relies on the provided Marshaller for marshalling keys and values to be send over to the remote Infinispan cluster.
RemoteCacheManager(Marshaller, Properties) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(Marshaller, java.util.Properties, boolean) with start = true.
RemoteCacheManager(Marshaller, Properties, ExecutorFactory) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(Marshaller, java.util.Properties, boolean) with start = true.
RemoteCacheManager(Marshaller, Properties, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(Marshaller, java.util.Properties, boolean) with start = true.
RemoteCacheManager(Properties, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Build a cache manager based on supplied properties.
RemoteCacheManager(Properties, boolean, ClassLoader, ExecutorFactory) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Build a cache manager based on supplied properties.
RemoteCacheManager(Properties) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties, boolean), and it also starts the cache (start==true).
RemoteCacheManager(Properties, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties, boolean), and it also starts the cache (start==true).
RemoteCacheManager(boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties), but it will try to lookup the config properties in the classpath, in a file named hotrod-client.properties.
RemoteCacheManager() - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(boolean) and it also starts the cache.
RemoteCacheManager(String, int, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Creates a remote cache manager aware of the Hot Rod server listening at host:port.
RemoteCacheManager(String, int, boolean, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Creates a remote cache manager aware of the Hot Rod server listening at host:port.
RemoteCacheManager(String, int) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(String, int, boolean) with start=true.
RemoteCacheManager(String, int, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(String, int, boolean) with start=true.
RemoteCacheManager(String, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
The given string should have the following structure: "host1:port2;host:port2...".
RemoteCacheManager(String, boolean, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
The given string should have the following structure: "host1:port2;host:port2...".
RemoteCacheManager(String) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(String, boolean), with start=true.
RemoteCacheManager(String, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(String, boolean), with start=true.
RemoteCacheManager(URL, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties), but it will try to lookup the config properties in supplied URL.
RemoteCacheManager(URL, boolean, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties), but it will try to lookup the config properties in supplied URL.
RemoteCacheManager(URL) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.net.URL) and it also starts the cache (start==true).
RemoteCacheManager(URL, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.net.URL) and it also starts the cache (start==true).
RemoteCacheManagerNotStartedException - Exception in org.infinispan.client.hotrod.exceptions
Thrown when trying to use an RemoteCache that is associated to an RemoteCacheManager that was not started.
RemoteCacheManagerNotStartedException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteCacheManagerNotStartedException
 
RemoteCacheProducer - Class in org.infinispan.cdi
The RemoteCache producer.
RemoteCacheProducer() - Constructor for class org.infinispan.cdi.RemoteCacheProducer
 
RemoteCacheStore - Class in org.infinispan.loaders.remote
Cache store that delegates the call to a infinispan cluster.
RemoteCacheStore() - Constructor for class org.infinispan.loaders.remote.RemoteCacheStore
 
RemoteCacheStoreConfig - Class in org.infinispan.loaders.remote
Configuration for RemoteCacheStore.
RemoteCacheStoreConfig() - Constructor for class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
RemoteCacheSupport<K,V> - Class in org.infinispan.client.hotrod.impl
Purpose: keep all delegating and unsupported methods in one place -> readability.
RemoteCacheSupport() - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
remoteCallTimeout(long) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
 
RemoteCommandsFactory - Class in org.infinispan.commands
Specifically used to create un-initialized ReplicableCommands from a byte stream.
RemoteCommandsFactory() - Constructor for class org.infinispan.commands.RemoteCommandsFactory
 
RemoteEventCacheStore - Class in org.infinispan.nearcache.jms
A remote cache store that registers itself to listen for remote cache events
RemoteEventCacheStore() - Constructor for class org.infinispan.nearcache.jms.RemoteEventCacheStore
 
RemoteEventCacheStore.RemoteEventCacheStoreConfig - Class in org.infinispan.nearcache.jms
 
RemoteEventCacheStore.RemoteEventCacheStoreConfig() - Constructor for class org.infinispan.nearcache.jms.RemoteEventCacheStore.RemoteEventCacheStoreConfig
 
RemoteEventListener - Class in org.infinispan.nearcache.jms
JMS listener that listens for remote cache events and invalidates cache contents.
RemoteEventListener(Cache<Object, Object>, StreamingMarshaller) - Constructor for class org.infinispan.nearcache.jms.RemoteEventListener
 
remoteExecutionFailed(Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
remoteLockIntention - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
remoteLocksAcquired(Collection<Address>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
RemoteNodeSuspecException - Exception in org.infinispan.client.hotrod.exceptions
When a remote node is suspected and evicted from the cluster while an operation is ongoing, the Hot Rod client emits this exception.
RemoteNodeSuspecException(String, long, short) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteNodeSuspecException
 
remoteStateRejected(Address, int, int) - Method in interface org.infinispan.util.logging.Log
 
RemoteTransaction - Class in org.infinispan.transaction
Defines the state of a remotely originated transaction.
RemoteTransaction(WriteCommand[], GlobalTransaction, int) - Constructor for class org.infinispan.transaction.RemoteTransaction
 
RemoteTransaction(GlobalTransaction, int) - Constructor for class org.infinispan.transaction.RemoteTransaction
 
remoteTransactionCommitted(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
Removes the RemoteTransaction corresponding to the given tx.
remoteTransactionCommitted(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
RemoteTransactionLogDetails - Class in org.infinispan.distribution
A holder for fetching transaction logs from a remote state provider
RemoteTransactionLogDetails(boolean, List<WriteCommand>, Collection<PrepareCommand>) - Constructor for class org.infinispan.distribution.RemoteTransactionLogDetails
 
RemoteTransactionLogDetails.Externalizer - Class in org.infinispan.distribution
 
RemoteTransactionLogDetails.Externalizer() - Constructor for class org.infinispan.distribution.RemoteTransactionLogDetails.Externalizer
 
remoteTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
remoteTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
Marks the transaction as prepared.
remoteTransactionRollback(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
remoteTransactionRollback(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
remoteTxAlreadyRegistered() - Method in interface org.infinispan.util.logging.Log
 
RemoteTxInvocationContext - Class in org.infinispan.context.impl
Context to be used for transaction that originated remotely.
RemoteTxInvocationContext() - Constructor for class org.infinispan.context.impl.RemoteTxInvocationContext
 
remove(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
remove(Object) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
remove(Object, Object) - Method in class org.infinispan.CacheImpl
 
remove(Object) - Method in class org.infinispan.CacheImpl
 
remove(byte[], Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
remove(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
remove(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
remove(Object, Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
remove(Object) - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
remove(Object) - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
remove(Object) - Method in interface org.infinispan.container.DataContainer
Removes an entry from the cache
remove() - Method in class org.infinispan.container.DefaultDataContainer.EntryIterator
 
remove(Object) - Method in class org.infinispan.container.DefaultDataContainer
 
remove(Object) - Method in class org.infinispan.DecoratedCache
 
remove(Object, Object) - Method in class org.infinispan.DecoratedCache
 
remove(Object) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Removes an entry in the store.
remove(Object) - Method in interface org.infinispan.loaders.CacheStore
Removes an entry in the store.
remove(Object) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
remove(Object) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Remove - Class in org.infinispan.loaders.modifications
Represents a CacheStore.remove(Object) modification
Remove(Object) - Constructor for class org.infinispan.loaders.modifications.Remove
 
remove(Object) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
remove() - Method in class org.infinispan.nearcache.cdi.AddressController
 
remove() - Method in class org.infinispan.query.clustered.DistributedIterator
 
remove() - Method in class org.infinispan.query.impl.EagerIterator
This method is not supported and should not be used.
remove() - Method in class org.infinispan.query.impl.LazyIterator
This method is not supported and should not be used.
remove() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
remove(K) - Method in interface org.infinispan.tree.Node
Removes the mapping for this key from this node if it is present.
remove(K, Flag...) - Method in interface org.infinispan.tree.Node
 
remove(K) - Method in class org.infinispan.tree.NodeImpl
 
remove(K, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
remove(Fqn, K) - Method in interface org.infinispan.tree.TreeCache
Removes the mapping for this key from a Node.
remove(Fqn, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
remove(String, K) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
remove(String, K, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
remove(Fqn, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(Fqn, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(String, K) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(String, K, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
remove(Flag) - Method in class org.infinispan.tree.TreeContext
 
remove(Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
remove(Object) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
remove(Object) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
remove(Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
remove(Object) - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
remove(Object) - Method in class org.infinispan.util.FastCopyHashMap
 
remove(int) - Method in class org.infinispan.util.ForwardingList
 
remove(Object) - Method in class org.infinispan.util.ForwardingList
 
remove(Object) - Method in class org.infinispan.util.ImmutableListCopy
 
remove(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
remove0(Object) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
REMOVE_HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of removal hits.
REMOVE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_IF_UNMODIFIED_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of removal misses.
REMOVE_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
removeAddress(ConsistentHash, Address, Configuration) - Static method in class org.infinispan.distribution.ch.ConsistentHashHelper
Returns a new consistent hash of the same type with the given address removed.
removeAddress(String) - Method in class org.infinispan.nearcache.cdi.AddressDao
 
removeAddressFromUnionConsistentHash(UnionConsistentHash, Address, Configuration) - Static method in class org.infinispan.distribution.ch.ConsistentHashHelper
Creates a new UnionConsistentHash instance based on the old instance, removing the provided address from both target consistent hash instances in the union.
removeAll(Collection<?>) - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
removeAll(Collection<?>) - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
removeAll(Set<Object>) - Method in class org.infinispan.loaders.AbstractCacheStore
 
removeAll(Set<Object>) - Method in interface org.infinispan.loaders.CacheStore
Bulk remove operation
removeAll(Set<Object>) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
removeAll(Set<Object>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
removeAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ForwardingList
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ImmutableListCopy
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
removeAsync(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeAsync(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeAsync(Object) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of Map.remove(Object).
removeAsync(Object, Object) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of ConcurrentMap.remove(Object, Object).
removeAsync(Object) - Method in class org.infinispan.CacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.CacheImpl
 
removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
removeAsync(Object, Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
removeAsync(Object) - Method in class org.infinispan.DecoratedCache
 
removeAsync(Object, Object) - Method in class org.infinispan.DecoratedCache
 
removeAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
Removes the atomic map associated with the given key from the underlying cache.
removeCache(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
Removes a cache with the given name, returning true if the cache was removed.
removeCache(String) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
removeCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
removeCache(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Removes a cache with the given name from the system.
RemoveCacheCommand - Class in org.infinispan.commands
Command to stop a cache and remove all its contents from both memory and any backing store.
RemoveCacheCommand(String, EmbeddedCacheManager, GlobalComponentRegistry) - Constructor for class org.infinispan.commands.RemoveCacheCommand
 
removeChannel(CacheListener.ChannelNotifyParams) - Method in class org.infinispan.server.websocket.CacheListener
 
removeChild(Fqn) - Method in interface org.infinispan.tree.Node
Removes a child node specified by the given relative Fqn.
removeChild(Fqn, Flag...) - Method in interface org.infinispan.tree.Node
 
removeChild(Object) - Method in interface org.infinispan.tree.Node
Removes a child node specified by the given name.
removeChild(Object, Flag...) - Method in interface org.infinispan.tree.Node
 
removeChild(Fqn) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Fqn, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(AdvancedCache<?, ?>, Fqn) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Object) - Method in class org.infinispan.tree.NodeImpl
 
removeChild(Object, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
removeChildren() - Method in interface org.infinispan.tree.Node
 
removeChildren(Flag...) - Method in interface org.infinispan.tree.Node
 
removeChildren() - Method in class org.infinispan.tree.NodeImpl
 
removeChildren(Flag...) - Method in class org.infinispan.tree.NodeImpl
 
RemoveCommand - Class in org.infinispan.commands.write
 
RemoveCommand(Object, Object, CacheNotifier, Set<Flag>) - Constructor for class org.infinispan.commands.write.RemoveCommand
 
RemoveCommand() - Constructor for class org.infinispan.commands.write.RemoveCommand
 
removed(Event<?, ?>) - Method in class org.infinispan.demo.InfinispanDemo.CacheListener
 
removeEntry(Object) - Method in class org.infinispan.loaders.bucket.Bucket
 
removeExpiredEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
removeFromIndexes(Object, Object) - Method in class org.infinispan.query.backend.QueryInterceptor
 
RemoveHandler - Class in org.infinispan.server.websocket.handlers
Cache "remove" operation handler.
RemoveHandler() - Constructor for class org.infinispan.server.websocket.handlers.RemoveHandler
 
removeIfUnmodified(byte[], long, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
RemoveIfUnmodifiedOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "removeIfUnmodified" operation as defined by Hot Rod protocol specification.
RemoveIfUnmodifiedOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], long) - Constructor for class org.infinispan.client.hotrod.impl.operations.RemoveIfUnmodifiedOperation
 
removeInterceptor(int) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(int) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor at a specified position, where the first interceptor in the chain is at position 0 and the last one at getInterceptorChain().size() - 1.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor of specified type.
removeInterceptor(int) - Method in class org.infinispan.CacheImpl
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.CacheImpl
 
removeInterceptor(int) - Method in class org.infinispan.interceptors.InterceptorChain
Removes the interceptor at the given postion.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Removes all the occurences of supplied interceptor type from the chain.
removeListener(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
removeListener(Object) - Method in class org.infinispan.CacheImpl
 
removeListener(Object) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
removeListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
removeListener(Object) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
removeListener(Object) - Method in interface org.infinispan.notifications.Listenable
Removes a listener from the component.
removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.TransactionTable
Removes the TransactionXaAdapter corresponding to the given tx.
removeLocalTransaction(Transaction) - Method in class org.infinispan.transaction.TransactionTable
 
removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
removeLocalTransaction(Transaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
removeLocalTransactionInternal(Transaction) - Method in class org.infinispan.transaction.TransactionTable
 
removeLockSafe(Object, Integer) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Removes an entry from a Bucket, locating the relevant Bucket using the key's hash code.
removeLockSafe(Object, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
removeLockSafe(Object, L) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.context.EntryLookup
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
removeNode(Fqn) - Method in interface org.infinispan.tree.TreeCache
Removes a Node indicated by absolute Fqn.
removeNode(Fqn, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
removeNode(String) - Method in interface org.infinispan.tree.TreeCache
Convenience method that takes a string representation of an Fqn.
removeNode(String, Flag...) - Method in interface org.infinispan.tree.TreeCache
 
removeNode(Fqn) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(Fqn, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(String) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeNode(String, Flag...) - Method in class org.infinispan.tree.TreeCacheImpl
 
removeObject(ITransaction, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
RemoveOperation<K,V> - Class in org.infinispan.atomic
An atomic remove operation.
RemoveOperation() - Constructor for class org.infinispan.atomic.RemoveOperation
 
RemoveOperation - Class in org.infinispan.client.hotrod.impl.operations
Implement "remove" operation as described in Hot Rod protocol specification.
RemoveOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.RemoveOperation
 
RemoveOperation.Externalizer - Class in org.infinispan.atomic
 
RemoveOperation.Externalizer() - Constructor for class org.infinispan.atomic.RemoveOperation.Externalizer
 
removeProperty(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
removeRecoveryInformation(Long) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Same as RecoveryManager.removeRecoveryInformation(javax.transaction.xa.Xid) but identifies the tx by its internal id.
removeRecoveryInformation(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Remove recovery information stored on this node (doesn't involve rpc).
removeRecoveryInformation(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformation(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformationFromCluster(Collection<Address>, Xid, boolean, GlobalTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information associated with these Xids.
removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Same as #removeRecoveryInformationFromCluster(java.util.Collection but the transaction is identified by its internal id, and not by its xid.
removeRecoveryInformationFromCluster(Collection<Address>, Xid, boolean, GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
removeRemoteTransaction(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
removeWithVersion(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeWithVersion(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
Removes the given entry only if its version matches the supplied version.
removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeWithVersionAsync(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
removingServer(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
renameFile(String, String) - Method in class org.infinispan.lucene.InfinispanDirectory
RepeatableReadEntry - Class in org.infinispan.container.entries
An extension of ReadCommittedEntry that provides Repeatable Read semantics
RepeatableReadEntry(Object, Object, EntryVersion, long) - Constructor for class org.infinispan.container.entries.RepeatableReadEntry
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of ConcurrentMap.replace(Object, Object), which takes in lifespan parameters.
replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of ConcurrentMap.replace(Object, Object), which takes in lifespan parameters.
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replace(K, V, V) - Method in class org.infinispan.CacheSupport
 
replace(K, V) - Method in class org.infinispan.CacheSupport
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replace(byte[], byte[], int, int, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V, V) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replace(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replace(K, V, V) - Method in class org.infinispan.DecoratedCache
 
replace(K, V) - Method in class org.infinispan.DecoratedCache
 
replace(K, V) - Method in interface org.infinispan.tree.Node
Replace entry for key only if currently mapped to some value.
replace(K, V, Flag...) - Method in interface org.infinispan.tree.Node
 
replace(K, V, V) - Method in interface org.infinispan.tree.Node
Replace entry for key only if currently mapped to given value.
replace(K, V, V, Flag...) - Method in interface org.infinispan.tree.Node
 
replace(K, V) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replace(K, V, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
replace(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
replace(K, V, V) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
replace(K, V) - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
replace(K, V, V) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
replace(K, V) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
REPLACE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_IF_UNMODIFIED_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
replaceAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.tree.Node
Similar to Node.putAll(java.util.Map) except that it removes any entries that exists in the data map first.
replaceAll(Map<? extends K, ? extends V>, Flag...) - Method in interface org.infinispan.tree.Node
 
replaceAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.tree.NodeImpl
 
replaceAll(Map<? extends K, ? extends V>, Flag...) - Method in class org.infinispan.tree.NodeImpl
 
replaceAncestor(Fqn, Fqn) - Method in class org.infinispan.tree.Fqn
Creates a new Fqn whose ancestor has been replaced with the new ancestor passed in.
replaceAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
replaceAsync(K, V) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of ConcurrentMap.replace(Object, Object).
replaceAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.replace(Object, Object, long, TimeUnit).
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.replace(Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, V) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of ConcurrentMap.replace(Object, Object, Object).
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.replace(Object, Object, Object, long, TimeUnit).
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Asynchronous version of BasicCache.replace(Object, Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, V) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V, V) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
This operation is not supported.
replaceAsync(K, V) - Method in class org.infinispan.DecoratedCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.DecoratedCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
ReplaceCommand - Class in org.infinispan.commands.write
 
ReplaceCommand() - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
ReplaceCommand(Object, Object, Object, CacheNotifier, long, long, Set<Flag>) - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
replaceIfUnmodified(byte[], byte[], int, int, long, Flag...) - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
ReplaceIfUnmodifiedOperation - Class in org.infinispan.client.hotrod.impl.operations
Implement "replaceIfUnmodified" as defined by Hot Rod protocol specification.
ReplaceIfUnmodifiedOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int, long) - Constructor for class org.infinispan.client.hotrod.impl.operations.ReplaceIfUnmodifiedOperation
 
replaceInterceptor(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
replaceKey(Object, Object) - Method in class org.infinispan.commands.control.LockControlCommand
 
replaceKeys(Map<Object, Object>) - Method in class org.infinispan.commands.control.LockControlCommand
 
ReplaceOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "Replace" operation as defined by Hot Rod protocol specification.
ReplaceOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.ReplaceOperation
 
replaceProperties(String) - Static method in class org.infinispan.util.StringPropertyReplacer
Go through the input string and replace any occurance of ${p} with the System.getProperty(p) value.
replaceProperties(String, Properties) - Static method in class org.infinispan.util.StringPropertyReplacer
Go through the input string and replace any occurance of ${p} with the props.getProperty(p) value.
replaceWithVersion(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceWithVersion(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersion(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersion(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
Replaces the given value only if its version matches the supplied version.
replaceWithVersion(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
A overloaded form of RemoteCache.replaceWithVersion(Object, Object, long) which takes in lifespan parameters.
replaceWithVersion(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
A overloaded form of RemoteCache.replaceWithVersion(Object, Object, long) which takes in lifespan and maximum idle time parameters.
replaceWithVersionAsync(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceWithVersionAsync(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersionAsync(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersionAsync(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
REPLICABLE_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
ReplicableCommand - Interface in org.infinispan.commands
The core of the command-based cache framework.
ReplicableCommandExternalizer - Class in org.infinispan.marshall.exts
ReplicableCommandExternalizer.
ReplicableCommandExternalizer(RemoteCommandsFactory, GlobalComponentRegistry) - Constructor for class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
ReplicatedStateTransferManagerImpl - Class in org.infinispan.statetransfer
The replicated mode implementation of StateTransferManager
ReplicatedStateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.ReplicatedStateTransferManagerImpl
Default constructor
ReplicatedStateTransferTask - Class in org.infinispan.statetransfer
Task which pushes keys to new nodes during join.
ReplicatedStateTransferTask(RpcManager, Configuration, DataContainer, ReplicatedStateTransferManagerImpl, StateTransferLock, CacheNotifier, int, Collection<Address>, ConsistentHash, ConsistentHash, boolean) - Constructor for class org.infinispan.statetransfer.ReplicatedStateTransferTask
 
ReplicationInterceptor - Class in org.infinispan.interceptors
Takes care of replicating modifications to other caches in a cluster.
ReplicationInterceptor() - Constructor for class org.infinispan.interceptors.ReplicationInterceptor
 
ReplicationQueue - Interface in org.infinispan.remoting
Periodically (or when certain size is exceeded) takes elements and replicates them.
ReplicationQueueFactory - Class in org.infinispan.factories
Factory for ReplicationQueue.
ReplicationQueueFactory() - Constructor for class org.infinispan.factories.ReplicationQueueFactory
 
ReplicationQueueImpl - Class in org.infinispan.remoting
A default implementation of the ReplicationQueue interface.
ReplicationQueueImpl() - Constructor for class org.infinispan.remoting.ReplicationQueueImpl
 
replicationQueueScheduledExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
replicationQueueScheduledExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
replicationQueueScheduledExecutor() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
replQueue() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
The replication queue in use, by default ReplicationQueueImpl.
replQueue(ReplicationQueue) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
The replication queue in use, by default ReplicationQueueImpl.
replQueueClass - Variable in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
replQueueClass(Class<? extends ReplicationQueue>) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
replQueueClass(Class<? extends ReplicationQueue>) - Method in interface org.infinispan.config.FluentConfiguration.AsyncConfig
Deprecated. This overrides the replication queue implementation class.
replQueueInterval - Variable in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
replQueueInterval(Long) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
replQueueInterval(Long) - Method in interface org.infinispan.config.FluentConfiguration.AsyncConfig
Deprecated. If useReplQueue is set to true, this attribute controls how often the asynchronous thread used to flush the replication queue runs.
replQueueInterval() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
If useReplQueue is set to true, this attribute controls how often the asynchronous thread used to flush the replication queue runs.
replQueueInterval(long) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
If useReplQueue is set to true, this attribute controls how often the asynchronous thread used to flush the replication queue runs.
replQueueMaxElements - Variable in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
replQueueMaxElements(Integer) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
replQueueMaxElements(Integer) - Method in interface org.infinispan.config.FluentConfiguration.AsyncConfig
Deprecated. If useReplQueue is set to true, this attribute can be used to trigger flushing of the queue when it reaches a specific threshold.
replQueueMaxElements() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
If useReplQueue is set to true, this attribute can be used to trigger flushing of the queue when it reaches a specific threshold.
replQueueMaxElements(int) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
If useReplQueue is set to true, this attribute can be used to trigger flushing of the queue when it reaches a specific threshold.
replTimeout - Variable in class org.infinispan.config.Configuration.SyncType
Deprecated.  
replTimeout(Long) - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.  
replTimeout(Long) - Method in interface org.infinispan.config.FluentConfiguration.SyncConfig
Deprecated. This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
replTimeout() - Method in class org.infinispan.configuration.cache.SyncConfiguration
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
replTimeout(long) - Method in class org.infinispan.configuration.cache.SyncConfiguration
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
replTimeout(long) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
REQUEST_BALANCING_STRATEGY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
REQUEST_IGNORED_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
REQUEST_MAGIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REQUEST_PARSING_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
RequestBalancingStrategy - Interface in org.infinispan.client.hotrod.impl.transport.tcp
Defines how request are distributed between the servers for replicated caches.
requestJoin(Address) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
Signal a join
requestLeave(Collection<Address>) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
Signal a leave.
requireAttributes(XMLStreamReader, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Require all the named attributes, returning their values in order.
requireNoAttributes(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Checks that the current element has no attributes, throwing an XMLStreamException if one is found.
requireNoContent(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Consumes the remainder of the current element, throwing an XMLStreamException if it contains any child elements.
requireNoNamespaceAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
requireSingleAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Require that the current element have only a single attribute with the given name.
RESEND_PREPARE - Static variable in class org.infinispan.commands.tx.CommitCommand
This is sent back to callers if the global transaction is not reconised.
reset() - Method in interface org.infinispan.context.FlagContainer
 
reset() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
reset() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
reset() - Method in class org.infinispan.context.impl.ImmutableContext
 
reset() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
reset() - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
reset() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
reset() - Method in interface org.infinispan.remoting.ReplicationQueue
Resets the replication queue, typically used when a cache is restarted.
reset() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
reset() - Method in class org.infinispan.tree.TreeContext
 
reset() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Resets variables maintaining the sum to zero.
resetChanges(CacheView) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
 
resetPassivationCount() - Method in interface org.infinispan.eviction.PassivationManager
 
resetPassivationCount() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
resetStatistics() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
Resets statistics gathered.
resetStatistics() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.TxInterceptor
 
resetStatistics() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Resets an interceptor's cache statistics
resetStatistics() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
resetStatistics() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
resetVolatileComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Removes any components not annotated as @SurvivesRestarts.
resolveCache(CacheInvocationContext<? extends Annotation>) - Method in interface org.infinispan.cdi.interceptor.CacheResolver
Resolve the Cache to use for this CacheInvocationContext.
resolveCache(CacheInvocationContext<? extends Annotation>) - Method in class org.infinispan.cdi.interceptor.DefaultCacheResolver
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.config.InfinispanContainerCacheManagerBeanDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.config.InfinispanRemoteCacheManagerBeanDefinitionParser
 
resolveModuleLifecycles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
 
resolveSchemaPath() - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
ResourceDMBean - Class in org.infinispan.jmx
This class was entirely copied from JGroups 2.7 (same name there).
ResourceDMBean(Object, ManageableComponentMetadata) - Constructor for class org.infinispan.jmx.ResourceDMBean
 
Response - Interface in org.infinispan.remoting.responses
A response to be sent back to a remote caller
RESPONSE_MAGIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
ResponseFilter - Interface in org.infinispan.remoting.rpc
A mechanism of filtering RPC responses.
ResponseGenerator - Interface in org.infinispan.remoting.responses
A component that generates responses as is expected by different cache setups
ResponseGeneratorFactory - Class in org.infinispan.factories
Creates a ResponseGenerator
ResponseGeneratorFactory() - Constructor for class org.infinispan.factories.ResponseGeneratorFactory
 
ResponseMode - Enum in org.infinispan.remoting.rpc
Represents different handling mechanisms when dealing with remote command responses.
restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
 
resume(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Resume the association of the calling thread with the given transaction.
resumeEncoding() - Method in class org.infinispan.util.Base64.OutputStream
Resumes encoding of the stream.
retainAll(Collection<?>) - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
retainAll(Collection<?>) - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
retainAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ForwardingList
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ImmutableListCopy
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
RETRIEVALS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get operations.
retrieveFromRemoteSource(Object, InvocationContext, boolean) - Method in interface org.infinispan.distribution.DistributionManager
Retrieves a cache entry from a remote source.
retrieveFromRemoteSource(Object, InvocationContext, boolean) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
retrieveKeyFromLazyQuery(Cache<?, ?>, UUID, int) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
retrievingTm(TransactionManager) - Method in interface org.infinispan.util.logging.Log
 
RetryOnFailureOperation<T> - Class in org.infinispan.client.hotrod.impl.operations
Base class for all the operations that need retry logic: if the operation fails due to connection problems, try with another available connection.
RetryOnFailureOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
retryWaitTimeIncreaseFactor - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
retryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
retryWaitTimeIncreaseFactor(Integer) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. Wait time increase factor over successive state retrieval backoffs
retryWaitTimeIncreaseFactorDeprecated() - Method in interface org.infinispan.util.logging.Log
 
returnPossiblePrevValue(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
returnType - Variable in class org.infinispan.tools.doclet.jmx.MBeanOperation
 
returnVersionedOperationResponse(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
reverseIterator() - Method in interface org.infinispan.util.ReversibleOrderedSet
 
ReversibleOrderedSet<E> - Interface in org.infinispan.util
A set that allows reverse iteration of the set elements, exposed via the ReversibleOrderedSet.reverseIterator() method.
rewind() - Method in interface org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap.ReusableIterator
 
rewire() - Method in class org.infinispan.factories.AbstractComponentRegistry
Rewires components.
rewireNamedRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
rewrapAsCacheException(Throwable) - Static method in class org.infinispan.util.Util
 
RhqPluginXmlGenerator - Class in org.infinispan.tools.rhq
RhqPluginDoclet.
RhqPluginXmlGenerator() - Constructor for class org.infinispan.tools.rhq.RhqPluginXmlGenerator
 
RhqUtil - Class in org.infinispan.rhq
RHQ utility methods
RhqUtil() - Constructor for class org.infinispan.rhq.RhqUtil
 
RiverCloseListener - Interface in org.infinispan.marshall.jboss
RiverCloseListener is used by Infinispan's extension of River Marshaller and Unmarshaller so that pools can be notified of instances not being in use anymore.
rnd - Static variable in class org.infinispan.affinity.RndKeyGenerator
 
RndKeyGenerator - Class in org.infinispan.affinity
Key provider that relies on Random's distribution to generate keys.
RndKeyGenerator() - Constructor for class org.infinispan.affinity.RndKeyGenerator
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
rollback(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
rollback() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
rollback() - Method in interface org.infinispan.container.entries.CacheEntry
Rolls back changes
rollback() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
rollback() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
rollback(ITransaction) - Method in class org.infinispan.demos.gridfs.GridStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.AbstractCacheStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Rolls back a transaction that has been previously prepared

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

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

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

rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
rollback(GlobalTransaction) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
rollback() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Rolls back the transaction associated with the calling thread.
rollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
Rolls back this transaction.
rollback() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Rolls back this transaction.
rollback(LocalTransaction) - Method in class org.infinispan.transaction.TransactionCoordinator
 
rollback(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
Same comment as for TransactionXaAdapter.prepare(javax.transaction.xa.Xid) applies for commit.
RollbackCommand - Class in org.infinispan.commands.tx
Command corresponding to a transaction rollback.
RollbackCommand(String, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
RollbackCommand(String) - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
rollbackView(int, int) - Method in class org.infinispan.cacheviews.CacheViewInfo
Discard the pending view
rollbackView(int, int) - Method in interface org.infinispan.cacheviews.CacheViewListener
Called before rolling back a cache view installation.
rollbackView(int, int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
rollingBackAfterError(Exception) - Method in interface org.infinispan.loaders.bdbje.logging.Log
 
ROOT - Static variable in class org.infinispan.tree.Fqn
Immutable root Fqn.
root() - Static method in class org.infinispan.tree.Fqn
 
rootDoc - Variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
RoundRobinBalancingStrategy - Class in org.infinispan.client.hotrod.impl.transport.tcp
Round-robin implementation for RequestBalancingStrategy.
RoundRobinBalancingStrategy() - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
rpc - Variable in class org.infinispan.distexec.DefaultExecutorService
 
RpcException - Exception in org.infinispan.remoting
Thrown when an RPC problem occurred
RpcException() - Constructor for exception org.infinispan.remoting.RpcException
 
RpcException(Throwable) - Constructor for exception org.infinispan.remoting.RpcException
 
RpcException(String) - Constructor for exception org.infinispan.remoting.RpcException
 
RpcException(String, Throwable) - Constructor for exception org.infinispan.remoting.RpcException
 
rpcManager - Variable in class org.infinispan.CacheImpl
 
rpcManager - Variable in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
rpcManager - Variable in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
RpcManager - Interface in org.infinispan.remoting.rpc
Provides a mechanism for communicating with other caches in the cluster, by formatting and passing requests down to the registered Transport.
rpcManager - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
rpcManager - Variable in class org.infinispan.transaction.TransactionTable
 
RpcManagerFactory - Class in org.infinispan.factories
A factory for the RpcManager
RpcManagerFactory() - Constructor for class org.infinispan.factories.RpcManagerFactory
 
RpcManagerImpl - Class in org.infinispan.remoting.rpc
This component really is just a wrapper around a Transport implementation, and is used to set up the transport and provide lifecycle and dependency hooks into external transport implementations.
RpcManagerImpl() - Constructor for class org.infinispan.remoting.rpc.RpcManagerImpl
 
run() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewTriggerThread
 
run() - Method in class org.infinispan.demo.distexec.PiApproximationDemo
 
run() - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
run() - Method in class org.infinispan.lucenedemo.DemoDriver
 
runCommitTx() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
runPrepare() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
runRollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
 

S

safeClose(InputStream) - Static method in class org.infinispan.loaders.AbstractCacheStore
 
safeClose(OutputStream) - Static method in class org.infinispan.loaders.AbstractCacheStore
 
safeClose(Statement) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(Connection) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeClose(ResultSet) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
safeEquals(Object, Object) - Static method in class org.infinispan.util.Util
Null-safe equality test.
safeRelease(L, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
Releases a lock and swallows any IllegalMonitorStateExceptions - so it is safe to call this method even if the lock is not locked, or not locked by the current thread.
sameCacheName(String) - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
sb - Variable in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
schedule(Runnable, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
ScheduledExecutorFactory - Interface in org.infinispan.executors
Used to configure and create scheduled executors
ScheduledExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
 
ScheduledExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
Configures executor factory.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
schema(XSSchema) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
SCHEMA_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
SCHEMA_URL_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
scheme() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
 
scheme(VersioningScheme) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
Scope - Annotation Type in org.infinispan.factories.scopes
Defines the scope of a component in a cache system.
ScopeDetector - Class in org.infinispan.factories.scopes
Retrieves the declared scope of a component
ScopeDetector() - Constructor for class org.infinispan.factories.scopes.ScopeDetector
 
Scopes - Enum in org.infinispan.factories.scopes
The different scopes that can be declared for a component in the cache system.
Search - Class in org.infinispan.query
Helper class to get a SearchManager out of an indexing enabled cache.
Search() - Constructor for class org.infinispan.query.Search
 
SearchableCacheConfiguration - Class in org.infinispan.query.backend
Class that implements org.hibernate.search.cfg.SearchConfiguration so that within Infinispan-Query, there is no need for a Hibernate Core configuration object.
SearchableCacheConfiguration(Class<?>[], Properties) - Constructor for class org.infinispan.query.backend.SearchableCacheConfiguration
 
searchCache(String) - Method in class org.infinispan.ec2demo.InfluenzaDataLoader
 
SearchManager - Interface in org.infinispan.query
The SearchManager is the entry point to create full text queries on top of a cache.
seek(long) - Method in class org.infinispan.lucene.InfinispanIndexInput
 
seek(long) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
seek(long) - Method in class org.infinispan.lucene.SingleChunkIndexInput
 
SegmentReadLocker - Interface in org.infinispan.lucene.readlocks
SegmentReadLocker implementations have to make sure that segments are not deleted while they are being used by an IndexReader.
selectExecutionNode(List<Address>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
selectExecutionNode() - Method in class org.infinispan.distexec.DefaultExecutorService
 
self - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
sendKeyOperation(byte[], Transport, byte, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
sendNotification(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
sendNotification(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
sendPutOperation(Transport, short, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
SEPARAOR - Static variable in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
SEPARATOR - Static variable in class org.infinispan.tree.Fqn
Separator between FQN elements.
serialisedSize - Variable in class org.infinispan.marshall.MarshalledValue
 
SerializableXid - Class in org.infinispan.transaction.xa.recovery
This xid implementation is needed because Xid is not Serializable and we need to serialize it and send it over the network.
SerializableXid(byte[], byte[], int) - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid
 
SerializableXid(Xid) - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid
 
SerializableXid.XidExternalizer - Class in org.infinispan.transaction.xa.recovery
 
SerializableXid.XidExternalizer() - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
 
serialization() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
serialization() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
serialization() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
SerializationConfiguration - Class in org.infinispan.configuration.global
 
SerializationConfigurationBuilder - Class in org.infinispan.configuration.global
Configures serialization and marshalling settings.
serialize(Object) - Method in class org.infinispan.loaders.jdbm.JdbmSerializer
 
serialize() - Method in class org.infinispan.marshall.MarshalledValue
 
SerializeWith - Annotation Type in org.infinispan.marshall
Indicate that this class should be serialized with an instance of the given externalizer class.
SerializeWithExtFactory - Class in org.infinispan.marshall.jboss
JBoss Marshalling plugin class for ClassExternalizerFactory that allows for Infinispan annotations to be used instead of JBoss Marshalling ones in order to discover which classes are serializable with Infinispan externalizers.
SerializeWithExtFactory() - Constructor for class org.infinispan.marshall.jboss.SerializeWithExtFactory
 
SERVER_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
SERVER_LIST - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
serverDidNotClose() - Method in interface org.infinispan.server.core.logging.JavaLog
 
serverDidNotUnbind() - Method in interface org.infinispan.server.core.logging.JavaLog
 
ServerStatistics - Interface in org.infinispan.client.hotrod
Defines the possible list of statistics defined by the Hot Rod server.
ServerStatisticsImpl - Class in org.infinispan.client.hotrod.impl
 
ServerStatisticsImpl() - Constructor for class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
set(K, V) - Method in class org.infinispan.AbstractDelegatingCache
Don't remove.
set(K, V) - Method in class org.infinispan.CacheImpl
 
set(K, V) - Method in class org.infinispan.CacheSupport
This is intentionally a non-public method meant as an integration point for bytecode manipulation.
set(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
set(byte[]) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
set(byte[]) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
set(Object) - Method in class org.infinispan.query.clustered.DistributedIterator
 
set(Object) - Method in class org.infinispan.query.impl.EagerIterator
This method is not supported in and should not be called.
set(Object) - Method in class org.infinispan.query.impl.LazyIterator
This method is not supported in and should not be called.
set(T) - Method in class org.infinispan.util.ByRef
 
set(int, E) - Method in class org.infinispan.util.ForwardingList
 
setAddress(Address) - Method in class org.infinispan.query.clustered.QueryResponse
 
setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setAdvancedExternalizer(AdvancedExternalizer<?>) - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
setAfterInterceptor(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Places the new interceptor directly after the instance of the named interceptor which is specified via its fully qualified class name.
setAfterInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.CustomInterceptorConfig
Places the new interceptor directly after the instance of the named interceptor which is specified via its fully qualified class name.
setAllowDuplicateDomains(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.GlobalJmxStatisticsType.allowDuplicateDomains(Boolean) instead
setAllowDuplicateDomains(boolean) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.allowDuplicateDomains(Boolean) instead
setAllowDuplicateDomains(boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setAlwaysProvideInMemoryState(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.alwaysProvideInMemoryState(Boolean) instead
setAlwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.alwaysProvideInMemoryState(Boolean) instead
setAlwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setAlwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setAlwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setAsText(String) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig.FsyncModeEditor
 
setAsyncExecutorFactory(ExecutorFactory) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setAsyncExecutorFactory(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setAsyncExecutorFactory(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setAsyncListenerExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.asyncListenerExecutor() instead
setAsyncListenerExecutorFactoryClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setAsyncListenerExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.asyncListenerExecutor() instead
setAsyncListenerExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.asyncListenerExecutor() instead
setAsyncListenerExecutorProperties(Properties) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setAsyncMarshalling(Boolean) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated. The visibility of this will be reduced, use Configuration.AsyncType.asyncMarshalling(Boolean)
setAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setAsyncStoreConfig(AsyncStoreConfig) - Method in interface org.infinispan.loaders.CacheStoreConfig
Deprecated. use CacheStoreConfig.asyncStore() instead
setAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setAsyncTransportExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.asyncTransportExecutor() instead
setAsyncTransportExecutorFactoryClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setAsyncTransportExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.asyncTransportExecutor() instead
setAsyncTransportExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.asyncTransportExecutor() instead
setAsyncTransportExecutorProperties(Properties) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAutoCreateKeyspace(boolean) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setBatchSize(int) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setBeanClass(Class<?>) - Method in class org.infinispan.tools.schema.TreeNode
 
setBeanName(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setBeanName(String) - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
 
setBeforeInterceptor(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Places the new interceptor directly before the instance of the named interceptor which is specified via its fully qualified class name..
setBeforeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.config.CustomInterceptorConfig
Places the new interceptor directly before the instance of the named interceptor which is specified via its fully qualified class name..
setBinaryTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setBucketId(Integer) - Method in class org.infinispan.loaders.bucket.Bucket
 
setBucketId(String) - Method in class org.infinispan.loaders.bucket.Bucket
 
setBucketPrefix(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setBucketTableNamePrefix(String) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStoreConfig
Sets the prefix for the name of the table where the data will be stored.
setCache(Cache<K, V>) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setCache(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
setCache(AdvancedCache<?, ?>) - Method in class org.infinispan.query.clustered.QueryBox
 
setCache(Cache<?, ?>) - Method in class org.infinispan.query.CommandInitializer
 
setCacheDbNamePrefix(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setCacheLoaderClassName(String) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
Fully qualified name of a cache loader class that must implement org.infinispan.loaders.CacheLoader interface
setCacheLoaderClassName(String) - Method in interface org.infinispan.loaders.CacheLoaderConfig
 
setCacheLoaderClassName(String) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setCacheLoaderConfigs(List<CacheLoaderConfig>) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated. The visibility of this method will be reduced and XMLElement definition is likely to move to the getCacheLoaderConfigs().
setCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LoadersConfig.addCacheLoader(org.infinispan.loaders.CacheLoaderConfig...) instead
setCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheManagerName(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.GlobalJmxStatisticsType.cacheManagerName(String) instead
setCacheManagerName(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.cacheManagerName(String) instead
setCacheManagerName(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setCacheManagerNotifier(CacheManagerNotifier) - Method in class org.infinispan.factories.ComponentRegistry
 
setCacheMode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead
setCacheMode(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead
setCacheModeString(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.ClusteringConfig.mode(org.infinispan.config.Configuration.CacheMode) instead
setCacheModeString(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setCacheModeString(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setCacheModeString(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setCacheName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the table where data will be stored.
setCacheName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheName(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
Sets the name of the org.infinispan.Cache to be created.
setCacheName(String) - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
Sets the name of the org.infinispan.Cache to be created.
setCaches(Set<Address>) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
setCaches(Set<Address>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Sets the collection of cache addresses in the cluster.
setCaches(Set<Address>) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
setCaches(Collection<Address>) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
setCaches(Set<Address>) - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHash
 
setCaches(Set<Address>) - Method in class org.infinispan.distribution.ch.UnionConsistentHash
 
setCacheStopTimeout(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.cacheStopTimeout(Integer) instead
setCacheStopTimeout(Integer) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. The visibility of this will be reduced, use Configuration.TransactionType.cacheStopTimeout(Integer) instead
setCacheStore() - Method in class org.infinispan.interceptors.ActivationInterceptor
 
setCacheStoreConfig(AbstractCacheStoreConfig) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setCatalogDbName(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setChanged() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setChanged() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setChunkSize(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
setClassLoader(ClassLoader) - Method in class org.infinispan.config.Configuration
Deprecated.  
setClassLoader(ClassLoader) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setClassLoader(ClassLoader) - Method in class org.infinispan.context.impl.ImmutableContext
 
setClassLoader(ClassLoader) - Method in interface org.infinispan.context.InvocationContext
Sets the class loader associated for this invocation
setClassLoader(ClassLoader) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
setClassName(String) - Method in class org.infinispan.config.CustomInterceptorConfig
Fully qualified interceptor class name which must extend org.infinispan.interceptors.base.CommandInterceptor.
setClazz(String) - Method in class org.infinispan.config.GrouperConfiguration
The grouper class
setCloudService(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setCloudServiceLocation(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.clusterName(String) instead
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.clusterName(String) instead
setClusterName(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setCoinToss(long) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Sets the random number that defines the coin toss.
setComparatorClassName(String) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setCompletionFailed(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
 
setCompress(boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setConcurrencyLevel(Integer) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated. The visibility of this will be reduced, use Configuration.LockingType.concurrencyLevel(Integer) instead
setConcurrencyLevel(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.concurrencyLevel(Integer) instead
setConcurrencyLevel(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setConcurrencyLevel(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setConcurrencyLevel(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setConfiguration(Configuration) - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.InvocationBatching
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.JmxStatistics
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.LazyDeserialization
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
setConfiguration(Configuration) - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
setConfiguration(GlobalConfiguration) - Method in class org.infinispan.remoting.transport.AbstractTransport
 
setConfiguration(GlobalConfiguration) - Method in interface org.infinispan.remoting.transport.Transport
 
setConfiguration(Configuration) - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
setConfigurationFileLocation(Resource) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
Sets the location of the configuration file which will be used to configure the EmbeddedCacheManager the SpringEmbeddedCacheManager created by this FactoryBean delegates to.
setConfigurationProperties(Properties) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setConfigurationPropertiesFile(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setConfigurationPropertiesFileLocation(Resource) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setConfigurationTemplateMode(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
setConnectionFactoryClass(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConnectionFactoryConfig(ConnectionFactoryConfig) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
Jdbc connection string for connecting to the database.
setConnectionUrl(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConsistentHash(ConsistentHash) - Method in interface org.infinispan.distribution.DistributionManager
Sets the consistent hash implementation in use.
setConsistentHash(ConsistentHash) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
setConsistentHashAtEnd(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setConsistentHashAtStart(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setConsistentHashClass(String) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.consistentHashClass(Class)
setConsistentHashClass(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.HashConfig.consistentHashClass(Class) instead
setConsistentHashClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setConsistentHashClass(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setConsistentHashClass(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setContextFlag(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility method that sets a given context flag.
setContextFlag(AbstractInvocationContext.ContextFlag, boolean) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility value that sets or un-sets a context flag based on a boolean passed in
setCountry(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setCreated(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setCreated(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setCreated(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setCreated(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setCreated(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setCreateTableOnStart(boolean) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setCreateTableOnStartForBinary(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setCreateTableOnStartForStrings(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
Deprecated. Use Configuration.CustomInterceptorsType.add(org.infinispan.interceptors.base.CommandInterceptor) instead
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.CustomInterceptorCumulator.add(org.infinispan.interceptors.base.CommandInterceptor)
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setDatabaseType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the database dialect.
setDatabaseType(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
Sets the database dialect.
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the column where the StoredEntry will be binary stored.
setDataColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDataColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the type of the column where data will be binary stored.
setDataColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDataColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDataColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDatasourceJndiLocation(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setDatasourceJndiLocation(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
setDatasourceJndiLocation(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setDeadlockDetectionSpinDuration(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.DeadlockDetectionConfig.spinDuration(Long) instead
setDeadlockDetectionSpinDuration(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setDeadlockDetectionSpinDuration(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setDeadlockDetectionSpinDuration(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.InternalCacheFactory
Allows users to specify a default class loader to use for both the construction and running of the cache.
setDelegate(CacheStore) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
setDependencies(DataContainer) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
setDependencies(LockManager, DataContainer, EntryFactory, ClusteringDependentLogic) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
setDependencies(TransactionTable, RpcManager) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
setDependencies(EntryFactory) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
setDependencies(PassivationManager, DataContainer) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
setDistributedSyncTimeout(long) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.distributedSyncTimeout(Long) instead
setDistributedSyncTimeout(Long) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.distributedSyncTimeout(Long) instead
setDistributedSyncTimeout(long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
The name of the driver used for connecting to the database.
setDriverClass(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setDropTableOnExit(boolean) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setDropTableOnExitForBinary(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setDropTableOnExitForStrings(boolean) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setEagerLockSingleNode(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.eagerLockSingleNode(Boolean) instead
setEagerLockSingleNode(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. The visibility of this will be reduced, use Configuration.TransactionType.eagerLockSingleNode(Boolean) instead
setEagerLockSingleNode(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEagerLockSingleNode(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEagerLockSingleNode(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated. The visibility of this will be reduced, use Configuration.BooleanAttributeType.enabled(Boolean) instead
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated. The visibility of this will be reduced
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.InvocationBatching
Deprecated.  
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated. The visibility of this will be reduced
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.LazyDeserialization
Deprecated.  
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated. The visibility will be reduced
setEnabled(Boolean) - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated. The visibility of this will be reduced
setEnabled(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use AbstractConfigurationBeanWithGCR.globalJmxStatistics() instead
setEnabled(Boolean) - Method in class org.infinispan.config.GroupsConfiguration
 
setEnabled(Boolean) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Deprecated. The visibility of this method will be reduced in favour of more fluent writer method calls.
setEnableDeadlockDetection(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use AbstractFluentConfigurationBean.deadlockDetection() instead
setEnableDeadlockDetection(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEnableDeadlockDetection(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEnableDeadlockDetection(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEnableVersioning(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. 
setEnlisted(boolean) - Method in class org.infinispan.transaction.synchronization.SyncLocalTransaction
 
setEntries(Map<Object, Object>) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setEntryColumnFamily(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setEnvironment(Cache<K, V>, Set<K>) - Method in interface org.infinispan.distexec.DistributedCallable
Invoked by execution environment after DistributedCallable has been migrated for execution to a specific Infinispan node.
setEnvironmentPropertiesFile(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setEqualityPreferenceForInstance(boolean) - Method in class org.infinispan.marshall.MarshalledValue
 
setEvicted(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setEvicted(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setEvicted(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setEvicted(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setEvictionMaxEntries(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.EvictionConfig.maxEntries(Integer) instead
setEvictionMaxEntries(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionMaxEntries(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEvictionMaxEntries(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEvictionScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.evictionScheduledExecutor() instead
setEvictionScheduledExecutorFactoryClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionScheduledExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.evictionScheduledExecutor() instead
setEvictionScheduledExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.evictionScheduledExecutor() instead
setEvictionScheduledExecutorProperties(Properties) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy) instead
setEvictionStrategy(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.EvictionConfig.strategy(org.infinispan.eviction.EvictionStrategy) instead
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEvictionStrategyClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionStrategyClass(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEvictionStrategyClass(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEvictionThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy) instead
setEvictionThreadPolicy(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.EvictionConfig.threadPolicy(org.infinispan.eviction.EvictionThreadPolicy) instead
setEvictionThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEvictionThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEvictionThreadPolicyClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setEvictionThreadPolicyClass(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setEvictionThreadPolicyClass(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setEvictionWakeUpInterval(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.ExpirationConfig.wakeUpInterval(Long) instead
setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
setExecuting(Future<T>) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
setExpirationColumnFamily(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setExpirationLifespan(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.ExpirationConfig.lifespan(Long) instead
setExpirationLifespan(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setExpirationLifespan(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setExpirationLifespan(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setExpirationMaxIdle(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.ExpirationConfig.maxIdle(Long) instead
setExpirationMaxIdle(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setExpirationMaxIdle(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setExpirationMaxIdle(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setExpirationWakeUpInterval(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setExpirationWakeUpInterval(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setExpirationWakeUpInterval(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setExpiryDbNamePrefix(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setExpiryQueueSize(int) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setExposeGlobalJmxStatistics(boolean) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use AbstractConfigurationBeanWithGCR.globalJmxStatistics() instead
setExposeGlobalJmxStatistics(boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setExposeJmxStatistics(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use AbstractFluentConfigurationBean.jmxStatistics() instead
setExposeJmxStatistics(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setExposeJmxStatistics(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setExposeJmxStatistics(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setExposeJmxStats(boolean) - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
SetExternalizer - Class in org.infinispan.marshall.exts
Set externalizer for all set implementations, i.e.
SetExternalizer() - Constructor for class org.infinispan.marshall.exts.SetExternalizer
 
setExternalizerClass(String) - Method in class org.infinispan.config.AdvancedExternalizerConfig
Fully qualified class name of an AdvancedExternalizer implementation that knows how to marshall or unmarshall instances of one, or several, user-defined, types.
setFactory(String) - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
setFactory(String) - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
setFetchInMemoryState(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.fetchInMemoryState(Boolean) instead
setFetchInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.fetchInMemoryState(Boolean) instead
setFetchInMemoryState(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setFetchInMemoryState(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setFetchInMemoryState(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setFetchPersistentState(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, fetch persistent state when joining a cluster.
setFetchPersistentState(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
Deprecated. use CacheStoreConfig.fetchPersistentState(Boolean) instead
setFetchPersistentState(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setFetchSize(int) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setFirst(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this interceptor be the first one in the chain?
setFirstInChain(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Mainly used by unit tests to replace the interceptor chain with the starting point passed in.
setFlag(DeltaAwareCacheEntry.Flags) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
Utility method that sets the value of the given flag to true.
setFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Utility method that sets the value of the given flag to true.
setFlags(Flag[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
setFlags(Set<Flag>) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
setFlags(Set<Flag>) - Method in class org.infinispan.commands.control.LockControlCommand
 
setFlags(Set<Flag>) - Method in interface org.infinispan.commands.FlagAffectedCommand
Use it to store the flags from the InvocationContext into the Command before remoting the Command.
setFlags(Set<Flag>) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setFlags(Flag...) - Method in interface org.infinispan.context.FlagContainer
 
setFlags(Collection<Flag>) - Method in interface org.infinispan.context.FlagContainer
 
setFlags(Flag...) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setFlags(Collection<Flag>) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setFlags(Flag...) - Method in class org.infinispan.context.impl.ImmutableContext
 
setFlags(Collection<Flag>) - Method in class org.infinispan.context.impl.ImmutableContext
 
setFlags(Flag...) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
setFlags(Collection<Flag>) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
setFlags(Flag...) - Method in class org.infinispan.tree.TreeContext
 
setFlags(Collection<Flag>) - Method in class org.infinispan.tree.TreeContext
 
setFlushLockTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Deprecated. The visibility of this method will be reduced. Use AsyncStoreConfig.flushLockTimeout(Long) instead.
setForceReturnValues(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setForceReturnValues(boolean) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setFramed(boolean) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setFsyncInterval(long) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setFsyncMode(FileCacheStoreConfig.FsyncMode) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setFullLengthSequence(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setGanNucleoid(String) - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
setGenbankAccessionNumber(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setGenomeSequenceNumber(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.Configuration
Deprecated.  
setGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.control.LockControlCommand
 
setGroupManager(GroupManager) - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
setGroups(GroupsConfiguration) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.  
setHash(Hash) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
setHashFunction(Hash) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
setHashFunctionClass(String) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.hashFunctionClass(Class)
setHashFunctionClass(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.HashConfig.hashFunctionClass(Class) instead
setHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.ShutdownType.hookBehavior(org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior) instead
setHost(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setHost(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setHostAge(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setHostGender(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setHotRodClientProperties(Properties) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setHotRodClientPropertiesFile(String) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setId(Integer) - Method in class org.infinispan.config.AdvancedExternalizerConfig
This identifier distinguishes between different user-defined AdvancedExternalizer implementations, providing a more performant way to ship class information around rather than passing class names or class information in general around.
setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the column where the id will be stored.
setIdColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setIdColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
sql equivalent for java's String.
setIdColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setIdColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setIdentity(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setIgnoreModifications(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
setIgnoreModifications(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
Deprecated. use CacheStoreConfig.ignoreModifications(Boolean) instead
setIgnoreModifications(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setImplicitTransaction(boolean) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
setImplicitTransaction(boolean) - Method in interface org.infinispan.context.impl.TxInvocationContext
Marks this transaction as implicit; implicit transactions are started for transactional caches that have the autoCommit enabled.
setImplicitTransaction(boolean) - Method in class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
setIndex(Integer) - Method in class org.infinispan.config.CustomInterceptorConfig
A position at which to place this interceptor in the chain, with 0 being the first position.
setIndexingEnabled(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use AbstractFluentConfigurationBean.indexing() instead
setIndexingEnabled(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setIndexingEnabled(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setIndexingEnabled(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setIndexLocalOnly(Boolean) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated. Use Configuration.QueryConfigurationBean.indexLocalOnly(Boolean) instead
setIndexLocalOnly(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.IndexingConfig.indexLocalOnly(Boolean) instead
setIndexLocalOnly(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setIndexLocalOnly(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setIndexLocalOnly(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setInfinispanCacheContainer(CacheContainer) - Method in class org.infinispan.spring.support.InfinispanDefaultCacheFactoryBean
Sets the org.infinispan.manager.CacheContainer to be used for creating our Cache instance.
setInfinispanEmbeddedCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
Sets the org.infinispan.manager.EmbeddedCacheManager to be used for creating our Cache instance.
setInfinispanMarshaller(StreamingMarshaller) - Method in class org.infinispan.marshall.jboss.ExtendedRiverUnmarshaller
 
setInfinispanRemoteCacheManager(RemoteCacheManager) - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
Sets the org.infinispan.client.hotrod.RemoteCacheManager to be used for creating our Cache instance.
setInitialRetryWaitTime(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.initialRetryWaitTime(Long) instead
setInterceptor(CommandInterceptor) - Method in class org.infinispan.config.CustomInterceptorConfig
Returns a the interceptor that we want to add to the chain.
setInternalId(long) - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
 
setInternalId(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
setInternalId(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
setInvalidationThreshold(Integer) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated.  
setInvocationBatchingEnabled(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use AbstractFluentConfigurationBean.invocationBatching() instead
setInvocationBatchingEnabled(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setInvocationBatchingEnabled(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setInvocationBatchingEnabled(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated. The visibility of this will be reduced, use Configuration.LockingType.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead
setIsolationLevel(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.isolationLevel(org.infinispan.util.concurrent.IsolationLevel) instead
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setIsolationLevelClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setIsolationLevelClass(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setIsolationLevelClass(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setJmxDomain(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.GlobalJmxStatisticsType.jmxDomain(String) instead
setJmxDomain(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.jmxDomain(String) instead
setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
setJmxDomain(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setKey(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setKey(K) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setKey2StringMapperClass(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setKey2StringMapperClass(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Name of the class implementing Key2StringMapper.
setKeyMapper(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setKeys(Object[]) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
setKeySizeEstimate(int) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setKeySizeEstimate(int) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setKeySpace(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setL1CacheEnabled(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use AbstractFluentConfigurationBean.l1() instead
setL1CacheEnabled(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setL1CacheEnabled(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setL1CacheEnabled(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setL1InvalidationCleanupTaskFrequency(long) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated. The visibility of this will be reduced, use #invalidationReaperThreadFrequency(Long)
setL1InvalidationCleanupTaskFrequency(long) - Method in class org.infinispan.config.Configuration
Deprecated.  
setL1InvalidationThreshold(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.L1Config.invalidationThreshold(Integer) instead
setL1Lifespan(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.L1Config.lifespan(Long) instead
setL1Lifespan(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setL1Lifespan(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setL1Lifespan(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setL1OnRehash(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.L1Config.onRehash(Boolean) instead
setL1OnRehash(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setL1OnRehash(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setL1OnRehash(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setLast(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this interceptor be the last one in the chain?
setLastModified(long) - Method in class org.infinispan.lucene.FileMetadata
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setLazyPurgingOnly(boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setLength(int) - Method in class org.infinispan.io.GridFile.Metadata
 
setLifespan(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated. The visibility of this will be reduced, use Configuration.ExpirationType.lifespan(Long)
setLifespan(Long) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated. The visibility of this will be reduced, use Configuration.L1Type.lifespan(Long)
setLifespan(long) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setLifespan(long) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the lifespan of the entry.
setLifespan(long) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setLifespan(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Sets the lifespan of the entry.
setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setLifespan(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setLifespan(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setListener(CacheViewListener) - Method in class org.infinispan.cacheviews.CacheViewInfo
We only support one listener per cache.
setLocal(boolean) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
setLocalAddress(Address) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setLocalTransaction(LocalTransaction) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
setLocation(String) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setLocation(String) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
Deprecated. The visibility of this will be reduced, use FileCacheStoreConfig.location(String)
setLocation(String) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStoreConfig
 
setLockAcquisitionTimeout(Long) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated. The visibility of this will be reduced, use Configuration.LockingType.lockAcquisitionTimeout(Long) instead
setLockAcquisitionTimeout(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long) instead
setLockAcquisitionTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.lockAcquisitionTimeout(Long) instead
setLockAcquisitionTimeout(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setLockAcquisitionTimeout(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setLockAcquisitionTimeout(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setLockAcquistionTimeout(long) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setLockAcquistionTimeout(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockAcquistionTimeout(long) - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
setLockConcurrencyLevel(int) - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
Sets number of threads expected to use this class concurrently.
setLockConcurrencyLevelForBinary(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockConcurrencyLevelForStrings(int) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setLockingMode(LockingMode) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
setLockIntention(Object) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
setLockPlaceholder(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
Marks an entry as a lock placeholder
setLockPlaceholder(boolean) - Method in class org.infinispan.container.entries.NullMarkerEntryForRemoval
 
setLockPlaceholder(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setLocksHeldAtOrigin(Set<Object>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
setLogFlushTimeout(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.logFlushTimeout(Long) instead
setMachineId(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.machineId(String) instead
setMachineId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.machineId(String) instead
setMachineId(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
setMarshaller(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setMarshaller(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setMarshallerClass(String) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.SerializationType.marshallerClass(Class) instead
setMarshallerClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.SerializationConfig.marshallerClass(Class) instead
setMarshallerClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setMarshallVersion(short) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.SerializationConfig.version(short) instead
setMarshallVersion(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.SerializationConfig.version(String) instead
setMarshallVersion(short) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setMaxConnections(int) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setMaxEntries(Integer) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated. The visibility of this will be reduced, use Configuration.EvictionType.maxEntries(Integer)
setMaxIdle(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated. The visibility of this will be reduced, use Configuration.ExpirationType.maxIdle(Long)
setMaxIdle(long) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setMaxIdle(long) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the maximum idle time of the entry.
setMaxIdle(long) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setMaxIdle(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Sets the maximum idle time of the entry.
setMaxIdle(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setMaxNonProgressingLogWrites(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.maxNonProgressingLogWrites(Integer) instead
setMaxTxRetries(int) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStoreConfig
 
setMBeanServerLookup(String) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.GlobalJmxStatisticsType.mBeanServerLookupClass(Class) instead
setMBeanServerLookup(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.mBeanServerLookupClass(Class) instead
setMBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.mBeanServerLookup(org.infinispan.jmx.MBeanServerLookup) instead
setMBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setMBeanServerLookupClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setMBeanServerLookupInstance(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.GlobalJmxStatisticsType.mBeanServerLookup(org.infinispan.jmx.MBeanServerLookup) instead
setMBeanServerLookupInstance(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.mBeanServerLookup(org.infinispan.jmx.MBeanServerLookup) instead
setMBeanServerProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.GlobalJmxStatisticsConfig.withProperties(java.util.Properties) or FluentGlobalConfiguration.GlobalJmxStatisticsConfig.addProperty(String, String) instead
setMBeanServerProperties(Properties) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setMembers(List<Address>) - Method in class org.infinispan.demo.InfinispanDemo.ClusterTableModel
 
setMembersAtEnd(Collection<Address>) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setMembersAtStart(Collection<Address>) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setMergeView(boolean) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
setMissingModifications(boolean) - Method in class org.infinispan.transaction.RemoteTransaction
 
setMode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated. The visibility of this will be reduced, use #mode(CacheMode)
setModificationQueueSize(Integer) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Deprecated. 
setModifications(WriteCommand[]) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
setModifications(List<WriteCommand>) - Method in class org.infinispan.transaction.LocalTransaction
 
setModificationTime(long) - Method in class org.infinispan.io.GridFile.Metadata
 
setName(String) - Method in class org.infinispan.nearcache.cdi.AddressController
 
setNetworkFuture(Future<V>) - Method in class org.infinispan.distexec.DefaultExecutorService.DistributedRunnableFuture
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureBuilder
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
setNetworkFuture(Future<V>) - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
setNetworkFuture(Future<E>) - Method in class org.infinispan.util.concurrent.NoOpFuture
 
setNetworkFuture(Future<Object>) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
setNetworkFuture(Future<T>) - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
setNewMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setNewValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setNewViewId(long) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setNext(CommandInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Sets the next interceptor in the chain to the interceptor passed in.
setNodeAddress(Address) - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
setNodeName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.nodeName(String) instead
setNumOwners(Integer) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.numOwners(Integer)
setNumOwners(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.HashConfig.numOwners(Integer) instead
setNumOwners(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setNumOwners(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setNumOwners(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setNumRetries(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.numRetries(Integer) instead
setNumVirtualNodes(Integer) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.numVirtualNodes(Integer)
setNumVirtualNodes(Integer) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
setOldMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setOldValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setOnRehash(Boolean) - Method in class org.infinispan.config.Configuration.L1Type
Deprecated. The visibility of this will be reduced, use Configuration.L1Type.onRehash(Boolean)
setOrigin(Address) - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
setOrigin(Address) - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
setOrigin(Address) - Method in interface org.infinispan.commands.remote.CacheRpcCommand
Set the origin of the command
setOrigin(Address) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setOrigin(Address) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setOriginLocal(boolean) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
setOriginLocal(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setParameterClasses(Class<?>[]) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.LockControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.MapReduceCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.RemoveCacheCommand
 
setParameters(int, Object[]) - Method in interface org.infinispan.commands.ReplicableCommand
Used by the CommandsFactory to create a command from raw data read off a stream.
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.PrepareCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ClearCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.InvalidateCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.PutMapCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.RemoveCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
setPassivation(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated. The visibility of this method will be reduced. Use CacheLoaderManagerConfig.passivation(Boolean) instead.
setPassword(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setPassword(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setPassword(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
Database username's password.
setPassword(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setPingOnStartup(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setPingOnStartup(boolean) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setPort(int) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setPosition(CustomInterceptorConfig.Position) - Method in class org.infinispan.config.CustomInterceptorConfig
A position at which to place this interceptor in the chain.
setPositionAsString(String) - Method in class org.infinispan.config.CustomInterceptorConfig
A position at which to place this interceptor in the chain.
setPre(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setPreload(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated. The visibility of this method will be reduced. Use CacheLoaderManagerConfig.preload(Boolean) instead.
setPrepared(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
 
setPrepared(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
setPrepared(boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryAwareTransaction
 
setProperties(Properties) - Method in class org.infinispan.config.CustomInterceptorConfig
 
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated. Visibility will be reduced. Instead use GlobalConfiguration.FactoryClassWithPropertiesType.addProperty(String, String) or GlobalConfiguration.FactoryClassWithPropertiesType.withProperties(java.util.Properties) instead
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.GlobalJmxStatisticsType.withProperties(java.util.Properties) instead
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.withProperties(java.util.Properties) or GlobalConfiguration.TransportType.addProperty(String, String) instead
setProperties(Properties) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
setProperties(String) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
setProperty(String, String) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
setProperty(String, String) - Static method in class org.infinispan.util.SysPropertyActions
 
setProperty(String, String) - Method in class org.infinispan.util.TypedProperties
 
setPropertyIfAttributePresent(BeanDefinitionBuilder, Element, String) - Static method in class org.infinispan.spring.config.InfinispanNamespaceUtils
 
setProtein_Data(String, String) - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
setProxyHost(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setProxyPort(String) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setPurgeOnStartup(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, purges this cache store when it starts up.
setPurgeOnStartup(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
Deprecated. use CacheStoreConfig.purgeOnStartup(Boolean) instead
setPurgeOnStartup(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setPurgerThreads(Integer) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
Deprecated. use AbstractCacheStoreConfig.purgerThreads(Integer) instead
setPurgeSynchronously(Boolean) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
If true, CacheStore#purgeExpired() call will be done synchronously
setPurgeSynchronously(Boolean) - Method in interface org.infinispan.loaders.CacheStoreConfig
Deprecated. use CacheStoreConfig.purgeSynchronously(Boolean) instead
setPurgeSynchronously(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setPushStateTimeout(Long) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
Deprecated. The visibility of this method will be reduced. Use SingletonStoreConfig.pushStateTimeout(Long) instead.
setPushStateWhenCoordinator(Boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
Deprecated. The visibility of this method will be reduced. Use SingletonStoreConfig.pushStateWhenCoordinator(Boolean) instead.
setPutIfAbsent(boolean) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setRackId(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.rackId(String) instead
setRackId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.rackId(String) instead
setRackId(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setReadConsistencyLevel(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setRecoveryManager(RecoveryManager) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
setRehashEnabled(Boolean) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.rehashEnabled(Boolean)
setRehashEnabled(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.HashConfig.rehashEnabled(Boolean) instead
setRehashEnabled(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setRehashEnabled(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setRehashEnabled(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setRehashRpcTimeout(Long) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.rehashRpcTimeout(Long)
setRehashRpcTimeout(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.HashConfig.rehashRpcTimeout(Long) instead
setRehashRpcTimeout(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setRehashRpcTimeout(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setRehashRpcTimeout(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setRehashWait(Long) - Method in class org.infinispan.config.Configuration.HashType
Deprecated. The visibility of this will be reduced, use Configuration.HashType.rehashWait(Long)
setRehashWaitTime(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.HashConfig.rehashWait(Long) instead
setRehashWaitTime(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setRehashWaitTime(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setRehashWaitTime(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setRemote(boolean) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setRemoteCacheName(String) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setRemoteCallTimeout(long) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoaderConfig
Deprecated. The visibility of this will be reduced, ClusterCacheLoaderConfig.remoteCallTimeout(long)
setRemoteLockIntention(Collection<Object>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
setRemoteTransaction(RemoteTransaction) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setRemoved(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setReplayEntryWrapping(boolean) - Method in class org.infinispan.commands.tx.PrepareCommand
 
setReplicationQueueScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.replicationQueueScheduledExecutor() instead
setReplicationQueueScheduledExecutorFactoryClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setReplicationQueueScheduledExecutorProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.replicationQueueScheduledExecutor() instead
setReplicationQueueScheduledExecutorProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalTypes.replicationQueueScheduledExecutor() instead
setReplicationQueueScheduledExecutorProperties(Properties) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setReplQueueClass(String) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated. The visibility of this will be reduced, use Configuration.AsyncType.replQueueClass(Class)
setReplQueueClass(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueClass(Class) instead
setReplQueueClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setReplQueueClass(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setReplQueueClass(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setReplQueueInterval(Long) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated. The visibility of this will be reduced, use Configuration.AsyncType.replQueueInterval(Long)
setReplQueueInterval(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueInterval(Long) instead
setReplQueueInterval(long, TimeUnit) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueInterval(Long) instead
setReplQueueInterval(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setReplQueueInterval(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setReplQueueInterval(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setReplQueueMaxElements(Integer) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated. The visibility of this will be reduced, use Configuration.AsyncType.replQueueMaxElements(Integer)
setReplQueueMaxElements(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.AsyncConfig.replQueueMaxElements(Integer) instead
setReplQueueMaxElements(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setReplQueueMaxElements(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setReplQueueMaxElements(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setReplTimeout(Long) - Method in class org.infinispan.config.Configuration.SyncType
Deprecated. The visibility of this will be reduced, use Configuration.SyncType.replTimeout(Long)
setRequestBalancingStrategy(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setRequestBalancingStrategy(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setRequestTimeout(long) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setResourceContent(ITransaction, String, InputStream, String, String) - Method in class org.infinispan.demos.gridfs.GridStore
 
setRetryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.retryWaitTimeIncreaseFactor(Integer) instead
setReturnCacheEntry(boolean) - Method in class org.infinispan.commands.read.GetKeyValueCommand
Will make this method to return an CacheEntry instead of the corresponding value associated with the key.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Mark the transaction associated with the calling thread for rollback only.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Mark the transaction so that the only possible outcome is a rollback.
setRootDoc(RootDoc) - Method in class org.infinispan.tools.doclet.config.AbstractConfigHtmlGenerator
 
setSecure(boolean) - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
setSeed(long) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Throws UnsupportedOperationException.
setSequenceLength(int) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setServerList(Collection<InetSocketAddress>) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setServerList(Collection<InetSocketAddress>) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setServers(Collection<SocketAddress>) - Method in interface org.infinispan.client.hotrod.impl.transport.tcp.RequestBalancingStrategy
 
setServers(Collection<SocketAddress>) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
setShared(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated. The visibility of this method will be reduced. Use CacheLoaderManagerConfig.shared(Boolean) instead.
setSharedKeyspace(boolean) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setShutdownHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.ShutdownConfig.hookBehavior(org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior) instead
setShutdownHookBehavior(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.ShutdownConfig.hookBehavior(org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior) instead
setShutdownHookBehavior(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setShutdownTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Deprecated. The visibility of this method will be reduced. Use AsyncStoreConfig.shutdownTimeout(Long) instead.
setSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setSingletonStoreConfig(SingletonStoreConfig) - Method in interface org.infinispan.loaders.CacheStoreConfig
Deprecated. use CacheStoreConfig.singletonStore() instead
setSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setSingletonStoreEnabled(Boolean) - Method in class org.infinispan.loaders.decorators.SingletonStoreConfig
Deprecated. The visibility of this method will be reduced. Use CacheStoreConfig.singletonStore() instead.
setSiteId(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.siteId(String) instead
setSiteId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.siteId(String) instead
setSiteId(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setSize(long) - Method in class org.infinispan.lucene.FileMetadata
 
setSpinDuration(Long) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated. The visibility of this will be reduced, use Configuration.DeadlockDetectionType.spinDuration(Long)
setStackTrace(StackTraceElement[]) - Method in exception org.infinispan.marshall.NotSerializableException
 
setStartAutomatically(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setStateException - Variable in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
Reference to an exception that was raised during state installation on this cache.
setStateRetrievalChunkSize(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.chunkSize(Integer) instead
setStateRetrievalChunkSize(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalChunkSize(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalChunkSize(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStateRetrievalInitialRetryWaitTime(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long) instead
setStateRetrievalInitialRetryWaitTime(long, TimeUnit) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.initialRetryWaitTime(Long) instead
setStateRetrievalInitialRetryWaitTime(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalInitialRetryWaitTime(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalInitialRetryWaitTime(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStateRetrievalLogFlushTimeout(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long) instead
setStateRetrievalLogFlushTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.logFlushTimeout(Long) instead
setStateRetrievalLogFlushTimeout(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalLogFlushTimeout(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalLogFlushTimeout(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStateRetrievalMaxNonProgressingLogWrites(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.maxNonProgressingLogWrites(Integer) instead
setStateRetrievalMaxNonProgressingLogWrites(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalMaxNonProgressingLogWrites(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalMaxNonProgressingLogWrites(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStateRetrievalNumRetries(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.numRetries(Integer) instead
setStateRetrievalNumRetries(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalNumRetries(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalNumRetries(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStateRetrievalRetryWaitTimeIncreaseFactor(int) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.retryWaitTimeIncreaseFactor(Integer) instead
setStateRetrievalRetryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalRetryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalRetryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStateRetrievalTimeout(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.timeout(Long) instead
setStateRetrievalTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.StateRetrievalConfig.timeout(Long) instead
setStateRetrievalTimeout(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStateRetrievalTimeout(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setStateRetrievalTimeout(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.TxInterceptor
 
setStatisticsEnabled(boolean) - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Enables an interceptor's cache statistics If true, the interceptor will capture statistics and make them available through the mbean.
setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
setStatus(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
setStrategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated. The visibility of this will be reduced, use Configuration.EvictionType.strategy(EvictionStrategy)
setStreamBufferSize(int) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
Deprecated. The visibility of this will be reduced, use FileCacheStoreConfig.streamBufferSize(int) instead
setStreet(String) - Method in class org.infinispan.nearcache.cdi.AddressController
 
setStrictPeerToPeer(boolean) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.strictPeerToPeer(Boolean) instead
setStrictPeerToPeer(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.strictPeerToPeer(Boolean) instead
setStrictPeerToPeer(boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setStringsTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setStringsTableNamePrefix(String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
Sets the prefix for the name of the table where the data will be stored.
setSubgroupsMerged(List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setSubType(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setSyncCommitPhase(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.syncCommitPhase(Boolean) instead
setSyncCommitPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. The visibility of this will be reduced, use Configuration.TransactionType.syncCommitPhase(Boolean) instead
setSyncCommitPhase(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setSyncCommitPhase(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setSyncCommitPhase(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setSyncReplTimeout(long) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.SyncConfig.replTimeout(Long) instead
setSyncReplTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.SyncConfig.replTimeout(Long) instead
setSyncReplTimeout(Long) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setSyncReplTimeout(Long) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setSyncReplTimeout(Long) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setSyncRollbackPhase(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.syncRollbackPhase(Boolean) instead
setSyncRollbackPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. The visibility of this will be reduced, use Configuration.TransactionType.setSyncRollbackPhase(Boolean) instead
setSyncRollbackPhase(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setSyncRollbackPhase(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setSyncRollbackPhase(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setTableManipulation(TableManipulation) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
setTableNamePrefix(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTableNamePrefixForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTableNamePrefixForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTcpNoDelay(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setTcpNoDelay(boolean) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setterMethod(Class<?>, Class<?>) - Static method in class org.infinispan.util.BeanUtils
Returns a Method object corresponding to a setter that sets an instance of componentClass from target.
setterName(String) - Static method in class org.infinispan.util.BeanUtils
Retrieves a setter name based on a field name passed in
setterName(Class<?>) - Static method in class org.infinispan.util.BeanUtils
Returns a setter for a given class
setThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated. The visibility of this will be reduced, use Configuration.EvictionType.threadPolicy(EvictionThreadPolicy)
setThreadPoolSize(Integer) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Deprecated. The visibility of this method will be reduced. Use AsyncStoreConfig.threadPoolSize(Integer) instead.
setTimeout(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated. The visibility of this will be reduced, use Configuration.StateRetrievalType.timeout(Long) instead
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the name of the column where the timestamp (Long in java) will be stored.
setTimestampColumnName(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTimestampColumnNameForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnNameForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnType(String) - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
Sets the prefix for the name of the table where the data will be stored.
setTimestampColumnType(String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
setTimestampColumnTypeForBinary(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
setTimestampColumnTypeForStrings(String) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStoreConfig
 
settingMasterThreadsNotSupported() - Method in interface org.infinispan.server.core.logging.JavaLog
 
setTransaction(Transaction) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
setTransaction(Transaction) - Static method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Just used for unit tests
setTransactionId(GlobalTransaction) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.transactionManagerLookup(TransactionManagerLookup) instead
setTransactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setTransactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setTransactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.transactionManagerLookupClass(Class) instead
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. The visibility of this will be reduced, use Configuration.TransactionType.transactionManagerLookupClass(Class) instead
setTransactionManagerLookupClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setTransactionManagerLookupClass(String) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setTransactionManagerLookupClass(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setTransactionMode(TransactionMode) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
setTransactionSuccessful(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Change the transaction timeout for transactions started by the calling thread with the DummyBaseTransactionManager.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Change the transaction timeout for transactions started by the calling thread with the DummyUserTransaction.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
setTransport(Transport) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
setTransportClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.transportClass(Class) instead
setTransportClass(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.TransportType.transportClass(Class) instead
setTransportClass(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setTransportFactory(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setTransportFactory(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setTransportNodeName(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.nodeName(String) instead
setTransportNodeName(String) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setTransportProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.withProperties(java.util.Properties) or FluentGlobalConfiguration.TransportConfig.addProperty(String, String) instead
setTransportProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Use FluentGlobalConfiguration.TransportConfig.withProperties(java.util.Properties) or FluentGlobalConfiguration.TransportConfig.addProperty(String, String) instead
setTransportProperties(Properties) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setType(XSComplexType) - Method in class org.infinispan.tools.schema.TreeNode
 
setTypedProperties(TypedProperties) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
setUnlock(boolean) - Method in class org.infinispan.commands.control.LockControlCommand
 
setUnreliableReturnValues(Boolean) - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated. The visibility of this will be reduced, use Configuration.UnsafeType.unreliableReturnValues(Boolean) instead
setUnsafeUnreliableReturnValues(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.UnsafeConfig.unreliableReturnValues(Boolean) instead
setUnsafeUnreliableReturnValues(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setUnsafeUnreliableReturnValues(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setUnsafeUnreliableReturnValues(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setUpdatedEntryVersions(EntryVersionsMap) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
setUpdatedEntryVersions(EntryVersionsMap) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
setUpdatedVersions(EntryVersionsMap) - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
setupDependencies(DataContainer, CacheNotifier, Cache<Object, Object>, InterceptorChain, DistributionManager, InvocationContextContainer, TransactionTable, Configuration, Map<Byte, ModuleCommandInitializer>, RecoveryManager, StateTransferManager, LockManager, InternalEntryFactory) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
setUse1PcForAutoCommitTransactions(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
setUseAsyncMarshalling(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.AsyncConfig.asyncMarshalling(Boolean) instead
setUseAsyncMarshalling(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setUseAsyncMarshalling(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setUseAsyncMarshalling(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setUseDefaultRemoteCache(boolean) - Method in class org.infinispan.loaders.remote.RemoteCacheStoreConfig
 
setUseEagerLocking(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.TransactionConfig.useEagerLocking(Boolean) instead
setUseEagerLocking(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. The visibility of this will be reduced, use Configuration.TransactionType.useEagerLocking(Boolean) instead
setUseEagerLocking(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setUseEagerLocking(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setUseEagerLocking(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setUseFutureReturnType(boolean) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
setUseFutureReturnType(boolean) - Method in class org.infinispan.context.impl.ImmutableContext
 
setUseFutureReturnType(boolean) - Method in interface org.infinispan.context.InvocationContext
Sets whether the call requires a Future as return type.
setUseFutureReturnType(boolean) - Method in class org.infinispan.context.InvocationContextFlagsOverride
 
setUseLazyDeserialization(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use AbstractFluentConfigurationBean.storeAsBinary() instead
setUseLazyDeserialization(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setUseLazyDeserialization(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setUseLazyDeserialization(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setUseLockStriping(Boolean) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated. The visibility of this will be reduced, use Configuration.LockingType.useLockStriping(Boolean) instead
setUseLockStriping(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.useLockStriping(Boolean) instead
setUseLockStriping(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setUseLockStriping(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setUseLockStriping(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setUseReplQueue(Boolean) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated. The visibility of this will be reduced, use Configuration.AsyncType.useReplQueue(Boolean)
setUseReplQueue(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.AsyncConfig.useReplQueue(Boolean) instead
setUseReplQueue(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setUseReplQueue(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setUseReplQueue(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setUsername(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setUserName(String) - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
Database username.
setUserName(String) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
setUseXaXid(boolean) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
setValid(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setValid(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setValid(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setValid(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setValue(Object) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the value of the entry, returning the previous value
setValue(Object) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
setValue(Object) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setValue(V) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setValue(V) - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
setValue(Object, String, Object) - Static method in class org.infinispan.util.ReflectionUtil
 
setValue(V) - Method in class org.infinispan.util.SimpleImmutableEntry
 
setValues(Object, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
setValueSizeEstimate(int) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
setValueSizeEstimate(int) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
 
setVersion(EntryVersion) - Method in class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
setVersion(String) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated. The visibility of this will be reduced, use GlobalConfiguration.SerializationType.version(String) instead
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setVersion(EntryVersion) - Method in interface org.infinispan.container.entries.versioned.Versioned
Sets the version on this entry.
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue
 
setVersioningScheme(VersioningScheme) - Method in class org.infinispan.config.Configuration
Deprecated. 
setVersioningScheme(VersioningScheme) - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated. The visibility of this will be reduced, use Configuration.VersioningConfigurationBean.versioningScheme(org.infinispan.configuration.cache.VersioningScheme)
setVersionsSeen(EntryVersionsMap) - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
setVersionsSeenOnPrepareCommand(VersionedPrepareCommand, TxInvocationContext) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
setViewId(int) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setVirusName(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
setWakeUpInterval(Long) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated. Use FluentConfiguration.ExpirationConfig.wakeUpInterval(Long)
setWriteConsistencyLevel(String) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStoreConfig
 
setWriteSkewCheck(Boolean) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated. The visibility of this will be reduced, use Configuration.LockingType.writeSkewCheck(Boolean) instead
setWriteSkewCheck(boolean) - Method in class org.infinispan.config.Configuration
Deprecated. Use FluentConfiguration.LockingConfig.writeSkewCheck(Boolean) instead
setWriteSkewCheck(Boolean) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
setWriteSkewCheck(Boolean) - Method in class org.infinispan.spring.ConfigurationOverrides
 
setWriteSkewCheck(Boolean) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
setWriteSkewCheckFlag() - Method in class org.infinispan.container.IncrementalVersionableEntryFactoryImpl
 
setXid(Xid) - Method in class org.infinispan.transaction.xa.LocalXaTransaction
 
setXid(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
 
setXid(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
setXid(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
setYearFound(String) - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
shared - Variable in class org.infinispan.config.CacheLoaderManagerConfig
 
shared(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
shared(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.LoadersConfig
Deprecated. This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
shared() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
shared(boolean) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
sharedModeOnlyAllowed() - Method in interface org.infinispan.loaders.remote.logging.Log
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
shouldInvoke(InvocationContext) - Method in interface org.infinispan.commands.VisitableCommand
Used by the InboundInvocationHandler to determine whether the command should be invoked or not.
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.write.ClearCommand
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
shouldInvoke(InvocationContext) - Method in class org.infinispan.commands.write.PutMapCommand
 
shouldInvokeRemoteTxCommand(TxInvocationContext) - Static method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
shouldModifyIndexes(InvocationContext) - Method in class org.infinispan.query.backend.LocalQueryInterceptor
 
shouldModifyIndexes(InvocationContext) - Method in class org.infinispan.query.backend.QueryInterceptor
 
shouldRetry(int) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
shouldStartAndConnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
shouldStopAndDisconnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
showInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
shutdown() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
shutdown() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
shutdown() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
shutdown() - Method in class org.infinispan.distexec.DefaultExecutorService
 
shutdown() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
shutdown() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
shutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
ShutdownConfiguration - Class in org.infinispan.configuration.global
 
ShutdownConfigurationBuilder - Class in org.infinispan.configuration.global
 
ShutdownHookBehavior - Enum in org.infinispan.configuration.global
Behavior of the JVM shutdown hook registered by the cache
shutdownNow() - Method in class org.infinispan.distexec.DefaultExecutorService
 
shutdownNow() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
shutdownNow() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
shutdownNow() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
shutdownTimeout() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
Timeout to stop the cache store.
shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
 
shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
Timeout to stop the cache store.
shutdownTimeout - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
shutdownTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Timeout to stop the cache store.
signature - Variable in class org.infinispan.tools.doclet.jmx.MBeanOperation
 
SimpleClusteredVersion - Class in org.infinispan.container.versioning
A simple versioning scheme that is cluster-aware
SimpleClusteredVersion(int, long) - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersion
 
SimpleClusteredVersionGenerator - Class in org.infinispan.container.versioning
A version generator implementation for SimpleClusteredVersions
SimpleClusteredVersionGenerator() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
SimpleClusteredVersionGenerator.ViewIdUpdater - Class in org.infinispan.container.versioning
 
SimpleClusteredVersionGenerator.ViewIdUpdater() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.ViewIdUpdater
 
SimpleConnectionFactory - Class in org.infinispan.loaders.jdbc.connectionfactory
Connection factory implementation that will create database connection on a per invocation basis.
SimpleConnectionFactory() - Constructor for class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
SimpleImmutableEntry<K,V> - Class in org.infinispan.util
Where is Java 1.6?
SimpleImmutableEntry(Map.Entry<K, V>) - Constructor for class org.infinispan.util.SimpleImmutableEntry
 
SimpleImmutableEntry(K, V) - Constructor for class org.infinispan.util.SimpleImmutableEntry
 
simpleType(XSSimpleType) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
SingleChunkIndexInput - Class in org.infinispan.lucene
SingleChunkIndexInput can be used instead of InfinispanIndexInput to read a segment when it has a size small enough to fit in a single chunk.
SingleChunkIndexInput(AdvancedCache<?, ?>, FileCacheKey, FileMetadata) - Constructor for class org.infinispan.lucene.SingleChunkIndexInput
 
SingleKeyNonTxInvocationContext - Class in org.infinispan.context
 
SingleKeyNonTxInvocationContext(boolean) - Constructor for class org.infinispan.context.SingleKeyNonTxInvocationContext
 
SingleRpcCommand - Class in org.infinispan.commands.remote
Similar to MultipleRpcCommand, but it only aggregates a single command for replication.
SingleRpcCommand(String, ReplicableCommand) - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SingleRpcCommand(String) - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SINGLETON_LIST - Static variable in interface org.infinispan.marshall.Ids
 
SingletonListExternalizer - Class in org.infinispan.marshall.exts
SingletonListExternalizer.
SingletonListExternalizer() - Constructor for class org.infinispan.marshall.exts.SingletonListExternalizer
 
singletonStore() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfiguration
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
singletonStore - Variable in class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
 
singletonStore() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
singletonStore() - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationChildBuilder
 
singletonStore() - Method in interface org.infinispan.configuration.cache.LoaderConfigurationChildBuilder
 
singletonStore - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
singletonStore() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
singletonStore() - Method in interface org.infinispan.loaders.CacheStoreConfig
 
singletonStore() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
SingletonStore - Class in org.infinispan.loaders.decorators
SingletonStore is a delegating cache store used for situations when only one instance should interact with the underlying store.
SingletonStore(CacheStore, Cache<Object, Object>, SingletonStoreConfig) - Constructor for class org.infinispan.loaders.decorators.SingletonStore
 
SingletonStore.PushStateException - Exception in org.infinispan.loaders.decorators
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
SingletonStore.PushStateException(String, Throwable) - Constructor for exception org.infinispan.loaders.decorators.SingletonStore.PushStateException
 
SingletonStore.PushStateException(Throwable) - Constructor for exception org.infinispan.loaders.decorators.SingletonStore.PushStateException
 
SingletonStore.SingletonStoreListener - Class in org.infinispan.loaders.decorators
Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
SingletonStore.SingletonStoreListener() - Constructor for class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
 
SingletonStoreConfig - Class in org.infinispan.loaders.decorators
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
SingletonStoreConfig() - Constructor for class org.infinispan.loaders.decorators.SingletonStoreConfig
 
SingletonStoreConfiguration - Class in org.infinispan.configuration.cache
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
SingletonStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
siteId(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. The id of the site where this node runs.
siteId - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
siteId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
siteId() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
siteId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
The id of the site where this node runs.
size() - Method in class org.infinispan.AbstractDelegatingCache
 
size() - Method in class org.infinispan.atomic.AtomicHashMap
 
size() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
size() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
size() - Method in class org.infinispan.CacheImpl
 
size() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
size() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
size() - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
size() - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
size() - Method in interface org.infinispan.container.DataContainer
 
size() - Method in class org.infinispan.container.DefaultDataContainer
 
size() - Method in class org.infinispan.DecoratedCache
 
size() - Method in class org.infinispan.interceptors.InterceptorChain
Returns the number of interceptors in the chain.
size() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Overriden only to avoid unneeded synchronization
size() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Overriden only to avoid unneeded synchronization
size() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
 
size() - Method in class org.infinispan.io.MarshalledValueByteStream
 
size() - Method in class org.infinispan.io.ReadableGridFileChannel
 
size() - Method in class org.infinispan.tree.Fqn
 
size() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
size() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
size() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.FastCopyHashMap.EntrySet
 
size() - Method in class org.infinispan.util.FastCopyHashMap.KeySet
 
size() - Method in class org.infinispan.util.FastCopyHashMap
 
size() - Method in class org.infinispan.util.FastCopyHashMap.Values
 
size() - Method in class org.infinispan.util.ForwardingList
 
size() - Method in class org.infinispan.util.ImmutableListCopy
 
size() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
SizeCommand - Class in org.infinispan.commands.read
Command to calculate the size of the cache
SizeCommand(DataContainer) - Constructor for class org.infinispan.commands.read.SizeCommand
 
sizeUncommitted() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
skip(InvocationContext) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
if this is a shared cache loader and the call is of remote origin, pass up the chain
skip(InvocationContext) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
Method that skips invocation if: - No store defined or, - The context contains Flag.SKIP_CACHE_STORE or,
skip(long) - Method in class org.infinispan.io.GridInputStream
 
skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
SKIP_TOKEN_REPLACEMENT - Static variable in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
skipGet() - Method in class org.infinispan.cdi.interceptor.literal.CacheResultLiteral
 
skipKey(Object) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
skipKey(Object) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
Method that skips invocation if: - The store is a shared one and node storing the key is not the 1st owner of the key or, - This is an L1 put operation.
SO_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
sort(Sort) - Method in interface org.infinispan.query.CacheQuery
Allows lucene to sort the results.
sort(Sort) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
sort(Sort) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
sort(T[], Comparator<? super T>) - Static method in class org.infinispan.util.TimSort
 
sort(T[], int, int, Comparator<? super T>) - Static method in class org.infinispan.util.TimSort
 
spinDuration - Variable in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
spinDuration(Long) - Method in class org.infinispan.config.Configuration.DeadlockDetectionType
Deprecated.  
spinDuration(Long) - Method in interface org.infinispan.config.FluentConfiguration.DeadlockDetectionConfig
Deprecated. Time period that determines how often is lock acquisition attempted within maximum time allowed to acquire a particular lock
spinDuration() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Time period that determines how often is lock acquisition attempted within maximum time allowed to acquire a particular lock
spinDuration(long) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Time period that determines how often is lock acquisition attempted within maximum time allowed to acquire a particular lock
spinDuration - Variable in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
SpringCache - Class in org.infinispan.spring.provider
A Cache implementation that delegates to a org.infinispan.Cache instance supplied at construction time.
SpringCache(BasicCache<Object, Object>) - Constructor for class org.infinispan.spring.provider.SpringCache
 
SpringEmbeddedCacheManager - Class in org.infinispan.spring.provider
A CacheManager implementation that is backed by an Infinispan EmbeddedCacheManager instance.
SpringEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.spring.provider.SpringEmbeddedCacheManager
 
SpringEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.provider
A FactoryBean for creating an SpringEmbeddedCacheManager instance.
SpringEmbeddedCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
 
SpringRemoteCacheManager - Class in org.infinispan.spring.provider
A CacheManager implementation that is backed by an Infinispan RemoteCacheManager instance.
SpringRemoteCacheManager(RemoteCacheManager) - Constructor for class org.infinispan.spring.provider.SpringRemoteCacheManager
 
SpringRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.provider
A FactoryBean for creating an SpringRemoteCacheManager instance.
SpringRemoteCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
 
sqlFailureClosingConnection(Connection, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureFetchingAllStoredEntries(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureInsertingBucket(Bucket, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureIntegratingState(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureLoadingKey(String, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureReadingKey(Object, String, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureRemovingKeys(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureRetrievingConnection(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureStoringKey(String, int, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureStoringKeys(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureUnexpected(SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
sqlFailureUpdatingBucket(Bucket, SQLException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in interface org.infinispan.util.logging.Log
 
StaleTransactionCleanupService - Class in org.infinispan.transaction
Class responsible of cleaning transactions from the transaction table when nodes leave the cluster.
StaleTransactionCleanupService(TransactionTable) - Constructor for class org.infinispan.transaction.StaleTransactionCleanupService
 
STANDARD_NAMESPACES - Static variable in enum org.infinispan.configuration.parsing.Namespace
Set of all namespaces, excluding the special Namespace.UNKNOWN value.
start() - Method in class org.infinispan.AbstractDelegatingCache
 
start() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
start() - Method in class org.infinispan.CacheImpl
 
start() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
start() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
start(Codec, ConfigurationProperties, Collection<SocketAddress>, AtomicInteger, ClassLoader) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
start(Codec, ConfigurationProperties, Collection<SocketAddress>, AtomicInteger, ClassLoader) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
start() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
start() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
start() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
start() - Method in class org.infinispan.demos.directory.FilesystemDirectory
 
start() - Method in class org.infinispan.distribution.L1ManagerImpl
 
start() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
start() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
start() - Method in class org.infinispan.factories.AbstractComponentRegistry
This starts the components in the cache, connecting to channels, starting service threads, etc.
Start - Annotation Type in org.infinispan.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache starts.
start() - Method in class org.infinispan.factories.ComponentRegistry
 
start() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
start() - Method in class org.infinispan.interceptors.base.BaseCustomInterceptor
 
start() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
start() - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
Only does a sanity check.
start() - Method in class org.infinispan.interceptors.DistributionInterceptor
 
start() - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
start() - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
start() - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
start() - Method in class org.infinispan.jmx.CacheJmxRegistration
Here is where the registration is being performed.
start() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
On start, the mbeans are registered.
start() - Method in interface org.infinispan.lifecycle.Lifecycle
 
start() - Method in class org.infinispan.loaders.AbstractCacheStore
 
start() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Validates configuration, configures and opens the Environment, then opens the databases.
start() - Method in interface org.infinispan.loaders.CacheLoader
 
start() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
start() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
start() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
start() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
start() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
start() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
start() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
start() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
start() - Method in class org.infinispan.loaders.file.FileCacheStore
 
start() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
start(ConnectionFactoryConfig, ClassLoader) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Starts the connection factory.
start(ConnectionFactoryConfig, ClassLoader) - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
start(ConnectionFactoryConfig, ClassLoader) - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
start(ConnectionFactoryConfig, ClassLoader) - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
start() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
start() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
start(ConnectionFactory) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
start() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
start() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
start() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
start() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
start() - Method in class org.infinispan.manager.DefaultCacheManager
 
start() - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
start() - Method in class org.infinispan.nearcache.jms.RemoteEventCacheStore
 
start() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
start() - Method in class org.infinispan.remoting.ReplicationQueueImpl
Starts the asynchronous flush queue.
start() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
start() - Method in interface org.infinispan.remoting.transport.Transport
 
start(ResourceContext<CacheManagerComponent>) - Method in class org.infinispan.rhq.CacheComponent
Start the resource connection
start(ResourceContext<MBeanResourceComponent<?>>) - Method in class org.infinispan.rhq.CacheManagerComponent
Start the resource connection
start() - Method in interface org.infinispan.server.core.transport.Transport
 
start(Properties, EmbeddedCacheManager) - Method in class org.infinispan.server.websocket.WebSocketServer
 
start() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
Start the org.infinispan.client.hotrod.RemoteCacheManager that backs this SpringRemoteCacheManager.
start(RootDoc) - Static method in class org.infinispan.tools.doclet.config.ConfigDoclet
 
start(RootDoc) - Static method in class org.infinispan.tools.doclet.jmx.JmxDoclet
 
start(RootDoc) - Static method in class org.infinispan.tools.rhq.RhqPluginXmlGenerator
 
start(Configuration, RpcManager, InterceptorChain) - Method in class org.infinispan.transaction.StaleTransactionCleanupService
 
start() - Method in class org.infinispan.transaction.TransactionCoordinator
 
start() - Method in class org.infinispan.transaction.xa.TransactionFactory
 
start(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
start() - Method in class org.infinispan.tree.TreeCacheImpl
 
startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
startAutomatically - Variable in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
startBatch() - Method in class org.infinispan.AbstractDelegatingCache
 
startBatch() - Method in class org.infinispan.batch.BatchContainer
Starts a batch
startBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
startBatch() - Method in interface org.infinispan.Cache
Starts a batch.
startBatch() - Method in class org.infinispan.CacheImpl
 
startCache() - Method in class org.infinispan.demo.Demo
 
startCache() - Method in class org.infinispan.manager.DefaultCacheManager
 
startCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
startCaches(String...) - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
startCaches(String...) - Method in class org.infinispan.manager.DefaultCacheManager
 
startCaches(String...) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Starts a set of caches in parallel.
startChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
startDocument() - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startedReadingMap - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
startElement(String, String, String, Attributes) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startingJGroupsChannel() - Method in interface org.infinispan.util.logging.Log
 
startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startInterceptor() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
startJGroupsChannelIfNeeded() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
startObjectInput(InputStream, boolean) - Method in interface org.infinispan.marshall.StreamingMarshaller
Create and open a new ObjectInput for the given input stream.
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
startObjectOutput(OutputStream, boolean) - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
Deprecated. 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
startObjectOutput(OutputStream, boolean) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
startObjectOutput(OutputStream, boolean, int) - Method in interface org.infinispan.marshall.StreamingMarshaller
Create and open an ObjectOutput instance for the given output stream.
startObjectOutput(OutputStream, boolean) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated. 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
startObjectOutput(OutputStream, boolean) - Method in class org.infinispan.marshall.VersionAwareMarshaller
Deprecated. 
startPrefixMapping(String, String) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startStateTransfer(int, Collection<Address>, boolean) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
startTransport(int, boolean, int, int, TypedProperties) - Method in class org.infinispan.server.websocket.WebSocketServer
 
startWithArgs(String) - Method in interface org.infinispan.server.core.logging.JavaLog
 
state - Variable in class org.infinispan.factories.AbstractComponentRegistry
 
state - Variable in class org.infinispan.loaders.decorators.AsyncStore
 
StateChangingEntry - Interface in org.infinispan.container.entries
An entry that may have state, such as created, changed, valid, etc.
stateRetrieval - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
stateRetrieval() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
stateRetrieval() - Method in interface org.infinispan.config.FluentConfiguration.ClusteringConfig
Deprecated. Configure stateRetrieval sub element
stateRetrievalConfigurationDeprecated() - Method in interface org.infinispan.util.logging.Log
 
stateTransfer() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
stateTransfer() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Configure the stateTransfer sub element for distributed and replicated caches.
stateTransfer() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
Configures how state is transferred when a new cache joins the cluster.
StateTransferCancelledException - Exception in org.infinispan.statetransfer
Thrown when a state transfer is interrupted because there is another state transfer pending.
StateTransferCancelledException() - Constructor for exception org.infinispan.statetransfer.StateTransferCancelledException
 
stateTransferChunkSize - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
StateTransferConfiguration - Class in org.infinispan.configuration.cache
Configures how state is retrieved when a new cache joins the cluster.
StateTransferConfigurationBuilder - Class in org.infinispan.configuration.cache
Configures how state is transferred when a cache joins or leaves the cluster.
StateTransferControlCommand - Class in org.infinispan.commands.control
A control command to coordinate state transfer that may occur when nodes join or leave a cluster.
StateTransferControlCommand() - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommand(String) - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommand(String, StateTransferControlCommand.Type, Address, int, Collection<InternalCacheEntry>, Collection<LockInfo>) - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommand(String, StateTransferControlCommand.Type, Address, int) - Constructor for class org.infinispan.commands.control.StateTransferControlCommand
 
StateTransferControlCommand.Type - Enum in org.infinispan.commands.control
 
StateTransferException - Exception in org.infinispan.statetransfer
An exception to denote problems in transferring state between cache instances in a cluster
StateTransferException() - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(String) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(String, Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferException(Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferException
 
StateTransferInProgressException - Exception in org.infinispan.statetransfer
This exception is thrown when an operation cannot complete because a state transfer is in progress.
StateTransferInProgressException(int) - Constructor for exception org.infinispan.statetransfer.StateTransferInProgressException
 
StateTransferInProgressException(int, Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferInProgressException
 
StateTransferInProgressException(int, String) - Constructor for exception org.infinispan.statetransfer.StateTransferInProgressException
 
StateTransferInProgressException(int, String, Throwable) - Constructor for exception org.infinispan.statetransfer.StateTransferInProgressException
 
stateTransferLock - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
stateTransferLock - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
StateTransferLock - Interface in org.infinispan.statetransfer
Typically adding a command, the following pattern would be used:

if (stateTransferLock.acquireForCommand()) { try { // execute this command! } finally { stateTransferLock.releaseForCommand(cmd); } }

StateTransferLockImpl - Class in org.infinispan.statetransfer
This class implements a specialized lock that allows the state transfer process (which is not a single thread) to block new write commands for the duration of the state transfer.
StateTransferLockImpl() - Constructor for class org.infinispan.statetransfer.StateTransferLockImpl
 
StateTransferLockInterceptor - Class in org.infinispan.interceptors
An interceptor that blocks any commands when the StateTransferLock is locked.
StateTransferLockInterceptor() - Constructor for class org.infinispan.interceptors.StateTransferLockInterceptor
 
StateTransferLockReacquisitionException - Exception in org.infinispan.statetransfer
Internal exception, thrown when StateTransferLock.waitForStateTransferToEnd fails to re-acquire the state transfer lock after state transfer (most likely because the timeout expired).
StateTransferLockReacquisitionException(String) - Constructor for exception org.infinispan.statetransfer.StateTransferLockReacquisitionException
 
stateTransferManager - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
StateTransferManager - Interface in org.infinispan.statetransfer
A component that manages the state transfer when the topology of the cluster changes.
StateTransferManagerFactory - Class in org.infinispan.factories
Constructs StateTransferManager instances.
StateTransferManagerFactory() - Constructor for class org.infinispan.factories.StateTransferManagerFactory
 
StateTransferMonitor - Class in org.infinispan.remoting.transport.jgroups
 
StateTransferMonitor() - Constructor for class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
stateTransferTimeoutWaitingForJoinConfirmations(int, Map<Address, Integer>) - Method in interface org.infinispan.util.logging.Log
 
stateTransferTimeoutWaitingForPushConfirmations(int, Map<Address, Integer>) - Method in interface org.infinispan.util.logging.Log
 
stats() - Method in interface org.infinispan.client.hotrod.impl.protocol.HotRodOperations
 
stats() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
stats() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
Stats - Interface in org.infinispan.stats
Stats.
STATS_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
STATS_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
StatsImpl - Class in org.infinispan.stats
StatsImpl.
StatsImpl(InterceptorChain) - Constructor for class org.infinispan.stats.StatsImpl
 
StatsOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements to the stats operation as defined by Hot Rod protocol specification.
StatsOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
stop() - Method in class org.infinispan.AbstractDelegatingCache
 
stop() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
stop() - Method in class org.infinispan.CacheImpl
 
stop() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl
 
stop() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
stop() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
stop() - Method in class org.infinispan.DecoratedCache
 
stop() - Method in class org.infinispan.distribution.L1ManagerImpl
 
stop() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
stop() - Method in class org.infinispan.factories.AbstractComponentRegistry
Stops the cache and sets the cache status to ComponentStatus.TERMINATED once it is done.
Stop - Annotation Type in org.infinispan.factories.annotations
Method level annotation that indicates a (no-param) method to be called on a component registered in the ComponentRegistry when the cache stops.
stop() - Method in class org.infinispan.factories.ComponentRegistry
 
stop() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
stop() - Method in class org.infinispan.factories.NamedExecutorsFactory
 
stop() - Method in class org.infinispan.interceptors.base.BaseCustomInterceptor
 
stop() - Method in class org.infinispan.jmx.CacheJmxRegistration
Unregister when the cache is being stoped.
stop() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
On stop, the mbeans are unregistered.
stop() - Method in interface org.infinispan.lifecycle.Lifecycle
 
stop() - Method in class org.infinispan.loaders.AbstractCacheStore
 
stop() - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Stops transaction and purge processing and closes the SleepyCat environment.
stop() - Method in interface org.infinispan.loaders.CacheLoader
 
stop() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
stop() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
Closes all databases, ignoring exceptions, and nulls references to all database related information.
stop() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
stop() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
stop() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
stop() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
stop() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
stop() - Method in class org.infinispan.loaders.file.FileCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory
Closes the connection factory, including all allocated connections etc.
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ManagedConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
stop() - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
stop() - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
stop() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Closes all databases, ignoring exceptions, and nulls references to all database related information.
stop() - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
stop() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
stop() - Method in class org.infinispan.manager.DefaultCacheManager
 
stop() - Method in class org.infinispan.marshall.AbstractDelegatingMarshaller
 
stop() - Method in class org.infinispan.marshall.CacheMarshaller
 
stop() - Method in class org.infinispan.marshall.GlobalMarshaller
 
stop() - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
stop() - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
stop() - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
stop() - Method in interface org.infinispan.marshall.StreamingMarshaller
Stop the marshaller.
stop() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
stop() - Method in class org.infinispan.nearcache.jms.RemoteEventCacheStore
 
stop() - Method in class org.infinispan.remoting.ReplicationQueueImpl
Stops the asynchronous flush queue.
stop() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
stop() - Method in interface org.infinispan.remoting.transport.Transport
 
stop() - Method in class org.infinispan.rhq.CacheComponent
Tear down the rescource connection
stop() - Method in interface org.infinispan.server.core.transport.Transport
 
stop() - Method in class org.infinispan.server.websocket.WebSocketServer
 
stop() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
Stop the EmbeddedCacheManager this CacheManager delegates to.
stop() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
Stop the org.infinispan.client.hotrod.RemoteCacheManager that backs this SpringRemoteCacheManager.
stop() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
stop() - Method in class org.infinispan.transaction.StaleTransactionCleanupService
 
stop() - Method in class org.infinispan.tree.TreeCacheImpl
 
stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
stopBeforeDestroyFailed(CacheException) - Method in interface org.infinispan.util.logging.Log
 
stopChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
stoppingRpcDispatcher() - Method in interface org.infinispan.util.logging.Log
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Stores an entry
store(InternalCacheEntry) - Method in interface org.infinispan.loaders.CacheStore
Stores an entry
store(InternalCacheEntry) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Store - Class in org.infinispan.loaders.modifications
Modification representing CacheStore.store(org.infinispan.container.entries.InternalCacheEntry)
Store(InternalCacheEntry) - Constructor for class org.infinispan.loaders.modifications.Store
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
store() - Method in class org.infinispan.nearcache.cdi.AddressController
 
storeAddress(String, Address) - Method in class org.infinispan.nearcache.cdi.AddressDao
 
storeAsBinary() - Method in class org.infinispan.configuration.cache.Configuration
 
storeAsBinary() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
storeAsBinary() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
StoreAsBinaryConfiguration - Class in org.infinispan.configuration.cache
Controls whether when stored in memory, keys and values are stored as references to their original objects, or in a serialized, binary format.
StoreAsBinaryConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls whether when stored in memory, keys and values are stored as references to their original objects, or in a serialized, binary format.
storeCurrentBuffer(boolean) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
storeKeysAsBinary(Boolean) - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
storeKeysAsBinary(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.StoreAsBinaryConfig
Deprecated.  
storeKeysAsBinary() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Enables storing keys as binary.
storeKeysAsBinary(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Specify whether keys are stored as binary or not.
storeLockSafe(InternalCacheEntry, Integer) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Stores an entry in an appropriate Bucket, based on the key's hash code.
storeLockSafe(InternalCacheEntry, String) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
storeLockSafe(InternalCacheEntry, L) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
STORES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of put operations.
storeValuesAsBinary(Boolean) - Method in class org.infinispan.config.Configuration.StoreAsBinary
Deprecated.  
storeValuesAsBinary(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.StoreAsBinaryConfig
Deprecated.  
storeValuesAsBinary() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Enables storing values as binary.
storeValuesAsBinary(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Specify whether values are stored as binary or not.
strategy - Variable in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
strategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
strategy(EvictionStrategy) - Method in interface org.infinispan.config.FluentConfiguration.EvictionConfig
Deprecated. Eviction strategy.
strategy() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Eviction strategy.
strategy(EvictionStrategy) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Eviction strategy.
strategy() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Returns type of eviction algorithm (strategy).
streamBufferSize() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
streamBufferSize(int) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
streamBufferSize(int) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
StreamingMarshaller - Interface in org.infinispan.marshall
A specialization of Marshaller that supports streams.
streamingStateTransferNotPresent() - Method in interface org.infinispan.util.logging.Log
 
Streams - Class in org.infinispan.util.stream
A collection of stream related utility methods.
Streams() - Constructor for class org.infinispan.util.stream.Streams
 
strictPeerToPeer(Boolean) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. If set to true, RPC operations will fail if the named cache does not exist on remote nodes with a NamedCacheNotFoundException.
strictPeerToPeer - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
strictPeerToPeer(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
strictPeerToPeer() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
strictPeerToPeer(Boolean) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
If set to true, RPC operations will fail if the named cache does not exist on remote nodes with a NamedCacheNotFoundException.
string - Variable in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
stringMode - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
StringPropertyReplacer - Class in org.infinispan.util
A utility class for replacing properties in strings.
StringPropertyReplacer() - Constructor for class org.infinispan.util.StringPropertyReplacer
 
stringRepresentation - Variable in class org.infinispan.tree.Fqn
A cached string representation of this Fqn, used by toString to it isn't calculated again every time.
stringToElement(String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
stringToKey(String, ClassLoader) - Method in class org.infinispan.query.backend.KeyTransformationHandler
 
StripedLock - Class in org.infinispan.util.concurrent.locks
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
StripedLock() - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
This constructor just calls StripedLock.StripedLock(int) with a default concurrency value of 20.
StripedLock(int) - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
subList(int, int) - Method in class org.infinispan.util.ForwardingList
 
subList(int, int) - Method in class org.infinispan.util.ImmutableListCopy
 
submit(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submit(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submit(Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
submit(Runnable, V) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
submit(Callable<V>, K...) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submit(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits given Callable task for an execution on a single Infinispan node.
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submitEverywhere(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submitEverywhere(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submitEverywhere(Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submitEverywhere(Callable<V>, K...) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submitEverywhere(Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given Callable task for an execution on all available Infinispan nodes.
submitEverywhere(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given Callable task for an execution on all available Infinispan nodes using input keys specified by K input.
SUCCESSFUL_EMPTY_RESPONSE - Static variable in class org.infinispan.remoting.responses.SuccessfulResponse
 
SUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
successfullyAppliedState(Address) - Method in interface org.infinispan.util.logging.Log
 
SuccessfulResponse - Class in org.infinispan.remoting.responses
A successful response
SuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
SuccessfulResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
sum() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Returns the current sum.
sumThenReset() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
supportsKey(Class<?>) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.AbstractCacheStore
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.file.FileCacheStore
 
SurvivesRestarts - Annotation Type in org.infinispan.factories.annotations
This annotation is used for components that will be registered in the ComponentRegistry, that are meant to be retained in the component registry even after the component registry is stopped.
suspect(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
SuspectException - Exception in org.infinispan.remoting.transport.jgroups
Thrown when a member is suspected during remote method invocation
SuspectException() - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Address) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Address, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
suspend() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Suspend the association the calling thread has to a transaction, and return the suspended transaction.
suspendEncoding() - Method in class org.infinispan.util.Base64.OutputStream
Suspends encoding of the stream.
sync - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
sync() - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
sync() - Method in interface org.infinispan.config.FluentConfiguration.ClusteringConfig
Deprecated. Configure sync sub element.
sync() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Configure sync sub element.
sync() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
sync() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
If configured all communications are synchronous, in that whenever a thread sends a message sent over the wire, it blocks until it receives an acknowledgment from the recipient.
sync - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
syncCommitPhase - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
syncCommitPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. Important: enabling this might cause inconsistencies if multiple transactions update the same key concurrently.
syncCommitPhase(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. If true, the cluster-wide commit phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the commit was sent.
syncCommitPhase() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
syncCommitPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If true, the cluster-wide commit phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the commit was sent.
syncCommitPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If true, the cluster-wide commit phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the commit was sent.
SyncConfiguration - Class in org.infinispan.configuration.cache
If configured all communications are synchronous, in that whenever a thread sends a message sent over the wire, it blocks until it receives an acknowledgment from the recipient.
SyncConfigurationBuilder - Class in org.infinispan.configuration.cache
If configured all communications are synchronous, in that whenever a thread sends a message sent over the wire, it blocks until it receives an acknowledgment from the recipient.
SyncConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SyncConfigurationBuilder
 
SynchronizationAdapter - Class in org.infinispan.transaction.synchronization
Synchronization implementation for integrating with the TM.
SynchronizationAdapter(LocalTransaction, TransactionCoordinator, CommandsFactory, RpcManager, TransactionTable, ClusteringDependentLogic, Configuration) - Constructor for class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
SynchronizedRestarter - Class in org.infinispan.util.concurrent
A class that handles restarts of components via multiple threads.
SynchronizedRestarter() - Constructor for class org.infinispan.util.concurrent.SynchronizedRestarter
 
SyncLocalTransaction - Class in org.infinispan.transaction.synchronization
LocalTransaction implementation to be used with SynchronizationAdapter.
SyncLocalTransaction(Transaction, GlobalTransaction, boolean, int) - Constructor for class org.infinispan.transaction.synchronization.SyncLocalTransaction
 
syncMarshalling() - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
Enables synchronous marshalling.
syncProcessor - Variable in class org.infinispan.notifications.AbstractListenerImpl
 
syncRollbackPhase - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
syncRollbackPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
syncRollbackPhase(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. If true, the cluster-wide rollback phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the rollback was sent.
syncRollbackPhase() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If true, the cluster-wide rollback phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the rollback was sent.
syncRollbackPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If true, the cluster-wide rollback phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the rollback was sent.
syncRollbackPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If true, the cluster-wide rollback phase in two-phase commit (2PC) transactions will be synchronous, so Infinispan will wait for responses from all nodes to which the rollback was sent.
syncs - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
SysPropertyActions - Class in org.infinispan.util
Priviledged actions for the package
SysPropertyActions() - Constructor for class org.infinispan.util.SysPropertyActions
 

T

tableExists(Connection, String) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
tableExists(Connection) - Method in class org.infinispan.loaders.jdbc.TableManipulation
 
tableManipulation - Variable in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
TableManipulation - Class in org.infinispan.loaders.jdbc
Contains all the logic of manipulating the table, including creating it if needed and access operations like inserting, selecting etc.
TableManipulation(String, String, String, String, String, String, String) - Constructor for class org.infinispan.loaders.jdbc.TableManipulation
 
TableManipulation() - Constructor for class org.infinispan.loaders.jdbc.TableManipulation
 
take() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
target - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
TCP_NO_DELAY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
TcpTransport - Class in org.infinispan.client.hotrod.impl.transport.tcp
Transport implementation based on TCP.
TcpTransport(InetSocketAddress, TransportFactory) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
TcpTransportFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
TcpTransportFactory() - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
testImmutability(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Checks field modifications via setters
TestingJmsClient - Class in org.infinispan.demo.nearcache.client
Testing client
TestingJmsClient() - Constructor for class org.infinispan.demo.nearcache.client.TestingJmsClient
 
testListenerClassValidity(Class<?>) - Static method in class org.infinispan.notifications.AbstractListenerImpl
Tests if a class is properly annotated as a CacheListener and returns whether callbacks on this class should be invoked synchronously or asynchronously.
testListenerMethodValidity(Method, Class<?>, String) - Static method in class org.infinispan.notifications.AbstractListenerImpl
 
THREAD_NAME - Static variable in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
threadDump() - Static method in class org.infinispan.util.Util
 
ThreadLocalRandom - Class in org.infinispan.util.concurrent.jdk7backported
A random number generator isolated to the current thread.
threadPolicy - Variable in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
threadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.config.Configuration.EvictionType
Deprecated.  
threadPolicy(EvictionThreadPolicy) - Method in interface org.infinispan.config.FluentConfiguration.EvictionConfig
Deprecated. Threading policy for eviction.
threadPolicy() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Threading policy for eviction.
threadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Threading policy for eviction.
threadPoolSize() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
Size of the thread pool whose threads are responsible for applying the modifications.
threadPoolSize(int) - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
Size of the thread pool whose threads are responsible for applying the modifications.
threadPoolSize - Variable in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
threadPoolSize(Integer) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Size of the thread pool whose threads are responsible for applying the modifications.
THRESHOLD - Static variable in class org.infinispan.affinity.KeyAffinityServiceImpl
 
thresholdExpired() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Returns true if batching threshold has expired, false otherwise.
TIME_SINCE_START - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of seconds since Hot Rod started.
timeout - Variable in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
timeout(Long) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.  
timeout(Long) - Method in interface org.infinispan.config.FluentConfiguration.StateRetrievalConfig
Deprecated. This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
timeout() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
timeout(long) - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
timeout(long) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
TimeoutConfigurationValidatingVisitor - Class in org.infinispan.config
TimeoutConfigurationValidatingVisitor checks transport related timeout relationships of InfinispanConfiguration instance.
TimeoutConfigurationValidatingVisitor() - Constructor for class org.infinispan.config.TimeoutConfigurationValidatingVisitor
 
TimeoutException - Exception in org.infinispan.util.concurrent
Thrown when a timeout occurred.
TimeoutException() - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
TimeoutException(String) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
 
timestampOfFirstEntryToExpire() - Method in class org.infinispan.loaders.bucket.Bucket
 
TimSort<T> - Class in org.infinispan.util
TimSort, backported from JDK7 sources (build openjdk-7-ea-src-b77-03_dec_2009).
tm_ - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
toArray() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
toArray(T[]) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
toArray() - Method in class org.infinispan.util.ForwardingList
 
toArray(T[]) - Method in class org.infinispan.util.ForwardingList
 
toArray() - Method in class org.infinispan.util.ImmutableListCopy
 
toArray(T[]) - Method in class org.infinispan.util.ImmutableListCopy
 
toArray() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
toArray(T[]) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
toAsync() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.  
toAsync() - Method in enum org.infinispan.configuration.cache.CacheMode
 
toClassArray(String[]) - Static method in class org.infinispan.util.ReflectionUtil
 
toHexString(byte[]) - Static method in class org.infinispan.util.Util
 
toHexString(byte[], int) - Static method in class org.infinispan.util.Util
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
toInternalCacheEntry(Object) - Method in interface org.infinispan.container.entries.InternalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
toInternalCacheValue() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Creates a representation of this entry as an InternalCacheValue.
toInternalCacheValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
toJDKByteBuffer() - Method in class org.infinispan.io.ByteBuffer
 
toJGroupsAddress(Address) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
toJSON(String, Object, String) - Static method in class org.infinispan.server.websocket.ChannelUtils
Cache key, value and cache-name to JSON string.
toManageableComponentMetadata() - Method in class org.infinispan.factories.components.ComponentMetadata
 
toManageableComponentMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
toMap(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
TOPOLOGY_AWARE_CH - Static variable in interface org.infinispan.marshall.Ids
 
TopologyAwareAddress - Interface in org.infinispan.remoting.transport
Wraps a TopologyUUID JGroups address
TopologyAwareConsistentHash - Class in org.infinispan.distribution.ch
Consistent hash that is aware of cluster topology.
TopologyAwareConsistentHash() - Constructor for class org.infinispan.distribution.ch.TopologyAwareConsistentHash
 
TopologyAwareConsistentHash(Hash) - Constructor for class org.infinispan.distribution.ch.TopologyAwareConsistentHash
 
TopologyAwareConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
TopologyAwareConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.ch.TopologyAwareConsistentHash.Externalizer
 
TopologyChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the ConsistentHash implementation in use by the DistributionManager changes due to a change in cluster topology.
TopologyChangedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
The event passed in to methods annotated with TopologyChanged.
topologyId - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
topologyId(AtomicInteger) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.bdbje.BdbjeCacheStore
Writes the current count of cachestore entries followed by a pair of byte[]s corresponding to the SleepyCat binary representation of key value.
toStream(ObjectOutput) - Method in interface org.infinispan.loaders.CacheStore
Loads the entire state into a stream, using whichever format is most efficient for the cache loader implementation.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
Writes to a stream the number of entries (long) then the entries themselves.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.mixed.JdbcMixedCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
Writes to a stream the number of entries (long) then the entries themselves.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.remote.RemoteCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStreamProcess(ResultSet, InputStream, ObjectOutput) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
toStreamSupport(ObjectOutput, byte, boolean) - Method in class org.infinispan.loaders.jdbc.DataManipulationHelper
 
toString() - Method in class org.infinispan.AbstractDelegatingCache
 
toString() - Method in class org.infinispan.atomic.AtomicHashMap
 
toString() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
toString() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
toString() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
toString() - Method in class org.infinispan.CacheImpl
 
toString() - Method in class org.infinispan.cacheviews.CacheView
 
toString() - Method in class org.infinispan.cdi.interceptor.context.CacheInvocationParameterImpl
 
toString() - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
toString() - Method in class org.infinispan.cdi.interceptor.context.metadata.AggregatedParameterMetaData
 
toString() - Method in class org.infinispan.cdi.interceptor.context.metadata.MethodMetaData
 
toString() - Method in class org.infinispan.cdi.interceptor.context.metadata.ParameterMetaData
 
toString() - Method in class org.infinispan.cdi.interceptor.DefaultCacheKey
 
toString() - Method in exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
toString() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
toString() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
toString() - Method in class org.infinispan.commands.control.CacheViewControlCommand
 
toString() - Method in class org.infinispan.commands.control.LockControlCommand
 
toString() - Method in class org.infinispan.commands.control.StateTransferControlCommand
 
toString() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
toString() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
toString() - Method in class org.infinispan.commands.read.EntrySetCommand
 
toString() - Method in class org.infinispan.commands.read.KeySetCommand
 
toString() - Method in class org.infinispan.commands.read.MapReduceCommand
 
toString() - Method in class org.infinispan.commands.read.SizeCommand
 
toString() - Method in class org.infinispan.commands.read.ValuesCommand
 
toString() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
toString() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
toString() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
toString() - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
toString() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
toString() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
toString() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
toString() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
toString() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
toString() - Method in class org.infinispan.commands.tx.CommitCommand
 
toString() - Method in class org.infinispan.commands.tx.PrepareCommand
 
toString() - Method in class org.infinispan.commands.tx.RollbackCommand
 
toString() - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
toString() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
toString() - Method in class org.infinispan.commands.write.ClearCommand
 
toString() - Method in class org.infinispan.commands.write.EvictCommand
 
toString() - Method in class org.infinispan.commands.write.InvalidateCommand
 
toString() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
toString() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
toString() - Method in class org.infinispan.commands.write.PutMapCommand
 
toString() - Method in class org.infinispan.commands.write.RemoveCommand
 
toString() - Method in class org.infinispan.commands.write.ReplaceCommand
 
toString() - Method in class org.infinispan.config.AdvancedExternalizerConfig
 
toString() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
toString() - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
toString() - Method in class org.infinispan.config.CustomInterceptorConfig
 
toString(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 
toString() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.AsyncLoaderConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.Configuration
 
toString() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.HashConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.L1Configuration
 
toString() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.LoaderConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.LockingConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.SyncConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
toString() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
toString() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
toString() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
toString() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
toString() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
toString() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
toString() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
toString() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
toString() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.MortalCacheValue
 
toString() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
toString() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
toString() - Method in class org.infinispan.container.entries.TransientCacheValue
 
toString() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
toString() - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue
 
toString() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
toString() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
toString() - Method in class org.infinispan.distribution.ch.AbstractConsistentHash
 
toString() - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
toString() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Entry
 
toString() - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash
 
toString() - Method in class org.infinispan.distribution.ch.VirtualAddress
 
toString() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
toString() - Method in class org.infinispan.distribution.RemoteTransactionLogDetails
 
toString() - Method in class org.infinispan.ec2demo.Influenza_N_P_CR_Element
 
toString() - Method in class org.infinispan.ec2demo.Nucleotide_Protein_Element
 
toString() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
toString() - Method in class org.infinispan.factories.components.ComponentMetadata
 
toString() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
toString() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
toString() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
toString() - Method in class org.infinispan.interceptors.InterceptorChain
 
toString() - Method in class org.infinispan.io.ByteBuffer
 
toString() - Method in class org.infinispan.io.GridFile.Metadata
 
toString() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.bucket.Bucket
 
toString() - Method in class org.infinispan.loaders.cassandra.CassandraCacheStore
 
toString() - Method in class org.infinispan.loaders.cloud.CloudCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
toString() - Method in class org.infinispan.loaders.jdbc.AbstractJdbcCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.jdbc.AbstractNonDelegatingJdbcCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactoryConfig
 
toString() - Method in class org.infinispan.loaders.jdbc.connectionfactory.SimpleConnectionFactory
 
toString() - Method in class org.infinispan.loaders.jdbc.stringbased.JdbcStringBasedCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.jdbm.JdbmCacheStore
 
toString() - Method in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.modifications.Clear
 
toString() - Method in class org.infinispan.loaders.modifications.ModificationsList
 
toString() - Method in class org.infinispan.loaders.modifications.Remove
 
toString() - Method in class org.infinispan.loaders.modifications.Store
 
toString() - Method in class org.infinispan.lucene.ChunkCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileListCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileMetadata
 
toString() - Method in class org.infinispan.lucene.FileReadLockKey
 
toString() - Method in class org.infinispan.lucene.InfinispanDirectory
 
toString() - Method in class org.infinispan.manager.DefaultCacheManager
 
toString() - Method in class org.infinispan.marshall.MarshalledValue
 
toString() - Method in class org.infinispan.nearcache.cdi.Address
 
toString() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
toString() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
toString() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
toString(Object) - Method in class org.infinispan.query.DefaultTransformer
 
toString(Object) - Method in interface org.infinispan.query.Transformer
 
toString() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
toString() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
toString() - Method in class org.infinispan.remoting.responses.ValidResponse
 
toString() - Method in exception org.infinispan.remoting.RpcException
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
toString() - Method in class org.infinispan.spring.provider.SpringCache
 
toString() - Method in class org.infinispan.statetransfer.LockInfo
 
toString() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
toString() - Method in class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
toString() - Method in class org.infinispan.tools.doclet.jmx.MBeanComponent
 
toString() - Method in class org.infinispan.tools.doclet.jmx.MBeanOperation
 
toString() - Method in class org.infinispan.tools.schema.TreeNode
 
toString() - Method in class org.infinispan.transaction.LocalTransaction
 
toString() - Method in class org.infinispan.transaction.RemoteTransaction
 
toString() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
toString() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
 
toString() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
toString() - Method in class org.infinispan.transaction.tm.DummyXid
 
toString() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
 
toString() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
toString() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
 
toString() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
toString() - Method in class org.infinispan.tree.Fqn
Returns this Fqn as a string, prefixing the first element with a Fqn.SEPARATOR and joining each subsequent element with a Fqn.SEPARATOR.
toString() - Method in class org.infinispan.tree.NodeImpl
 
toString() - Method in class org.infinispan.tree.NodeKey
 
toString() - Method in class org.infinispan.tree.TreeCacheImpl
 
toString() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
toString() - Method in class org.infinispan.util.ByteArrayKey
 
toString() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a string representation of this map.
toString() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
toString() - Method in exception org.infinispan.util.concurrent.TimeoutException
 
toString() - Method in class org.infinispan.util.FastCopyHashMap
Returns a string representation of this map.
toString() - Method in class org.infinispan.util.SimpleImmutableEntry
 
toStringArray(Class<?>[]) - Static method in class org.infinispan.util.ReflectionUtil
 
toSync() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.  
toSync() - Method in enum org.infinispan.configuration.cache.CacheMode
 
TOTAL_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of entries stored in Hot Rod server.
toTypedProperties(Properties) - Static method in class org.infinispan.client.hotrod.impl.TypedProperties
Factory method that converts a JDK Properties instance to an instance of TypedProperties, if needed.
toTypedProperties(Properties) - Static method in class org.infinispan.config.AbstractConfigurationBean
Converts a given Properties instance to an instance of TypedProperties
toTypedProperties(String) - Static method in class org.infinispan.config.AbstractConfigurationBean
 
toTypedProperties(Properties) - Static method in class org.infinispan.util.TypedProperties
Factory method that converts a JDK Properties instance to an instance of TypedProperties, if needed.
touch() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
touch() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Updates access timestamps on this instance
touch(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Updates access timestamps on this instance to a specified time
touch() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
touch() - Method in class org.infinispan.lucene.FileMetadata
 
touchFile(String) - Method in class org.infinispan.lucene.InfinispanDirectory
toXmlString() - Method in class org.infinispan.config.Configuration
Deprecated. Converts this configuration instance to an XML representation containing the current settings.
toXmlString() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated. Converts this configuration instance to an XML representation containing the current settings.
toXmlString(Object) - Static method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Converts an instance of GlobalConfiguration, Configuration or InfinispanConfiguration to its XML representation.
toXmlString() - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated. Converts this configuration instance to an XML representation containing the current settings.
trace - Variable in class org.infinispan.distribution.ch.AbstractWheelConsistentHash
 
trace - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
trace - Variable in class org.infinispan.statetransfer.BaseStateTransferTask
 
trace - Static variable in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
transaction() - Method in class org.infinispan.configuration.cache.Configuration
 
transaction() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
transaction() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
TRANSACTION_LOG_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
TransactionalEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
An event subtype that includes a transaction context - if one exists - as well as a boolean as to whether the call originated locally or remotely.
TransactionalEventTransactionContext - Class in org.infinispan.query.backend
This class implements the TransactionContext interface.
TransactionalEventTransactionContext(TransactionManager, TransactionSynchronizationRegistry) - Constructor for class org.infinispan.query.backend.TransactionalEventTransactionContext
Creates a new instance of NodeModifiedTransactionContext.
TransactionalInvocationContextContainer - Class in org.infinispan.context
Invocation context to be used for transactional caches.
TransactionalInvocationContextContainer() - Constructor for class org.infinispan.context.TransactionalInvocationContextContainer
 
TransactionalInvocationContextFlagsOverride - Class in org.infinispan.context
Extension of InvocationContextFlagsOverride to be used when a TxInvocationContext is required.
TransactionalInvocationContextFlagsOverride(TxInvocationContext, Set<Flag>) - Constructor for class org.infinispan.context.TransactionalInvocationContextFlagsOverride
 
TransactionalLockFactory - Class in org.infinispan.lucene.locking
Factory for locks obtained in InfinispanDirectory, this factory produces instances of TransactionalSharedLuceneLock.
TransactionalLockFactory(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.locking.TransactionalLockFactory
 
TransactionBoundaryCommand - Interface in org.infinispan.commands.tx
An transaction boundary command that allows the retrieval of an attached GlobalTransaction
TransactionCompleted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and the transaction completes, either with a commit or a rollback.
TransactionCompletedAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
TransactionCompletedAdapter(Event<TransactionCompletedEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.TransactionCompletedAdapter
 
TransactionCompletedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionCompleted.
TransactionConfiguration - Class in org.infinispan.configuration.cache
Defines transactional (JTA) characteristics of the cache.
TransactionConfigurationBuilder - Class in org.infinispan.configuration.cache
Defines transactional (JTA) characteristics of the cache.
TransactionConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
TransactionCoordinator - Class in org.infinispan.transaction
Coordinates transaction prepare/commits as received from the TransactionManager.
TransactionCoordinator() - Constructor for class org.infinispan.transaction.TransactionCoordinator
 
TransactionFactory - Class in org.infinispan.transaction.xa
Factory for transaction related sate.
TransactionFactory() - Constructor for class org.infinispan.transaction.xa.TransactionFactory
 
TransactionFactory.TxFactoryEnum - Enum in org.infinispan.transaction.xa
 
transactionManager - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
transactionManager - Variable in class org.infinispan.CacheImpl
 
transactionManager - Variable in class org.infinispan.query.backend.QueryInterceptor
 
TransactionManagerFactory - Class in org.infinispan.factories
Uses a number of mechanisms to retrieve a transaction manager.
TransactionManagerFactory() - Constructor for class org.infinispan.factories.TransactionManagerFactory
 
transactionManagerLookup - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionManagerLookup(TransactionManagerLookup) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. Configure Transaction manager lookup directly using an instance of TransactionManagerLookup.
transactionManagerLookup() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Configure Transaction manager lookup directly using an instance of TransactionManagerLookup.
transactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Configure Transaction manager lookup directly using an instance of TransactionManagerLookup.
TransactionManagerLookup - Interface in org.infinispan.transaction.lookup
Factory interface, allows Cache to use different transactional systems.
transactionManagerLookupClass - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionManagerLookupClass(Class<? extends TransactionManagerLookup>) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionManagerLookupClass(Class<? extends TransactionManagerLookup>) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. Fully qualified class name of a class that looks up a reference to a TransactionManager.
transactionMode(TransactionMode) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
transactionMode - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionMode(TransactionMode) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionMode(TransactionMode) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. Configures whether the cache is transactional or not.
transactionMode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
transactionMode(TransactionMode) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
TransactionMode - Enum in org.infinispan.transaction
Enumeration containing the available transaction modes for a cache.
TransactionRegistered - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and registers a Synchronization with a registered TransactionManager.
TransactionRegisteredAdapter<K,V> - Class in org.infinispan.cdi.event.cache
 
TransactionRegisteredAdapter(Event<TransactionRegisteredEvent<K, V>>) - Constructor for class org.infinispan.cdi.event.cache.TransactionRegisteredAdapter
 
TransactionRegisteredEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionRegistered.
transactionSynchronizationRegistry - Variable in class org.infinispan.query.backend.QueryInterceptor
 
TransactionSynchronizationRegistryFactory - Class in org.infinispan.factories
Factory for the TransactionSynchronizationRegistry
TransactionSynchronizationRegistryFactory() - Constructor for class org.infinispan.factories.TransactionSynchronizationRegistryFactory
 
transactionSynchronizationRegistryLookup - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionSynchronizationRegistryLookup(TransactionSynchronizationRegistryLookup) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
transactionSynchronizationRegistryLookup(TransactionSynchronizationRegistryLookup) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. Configure Transaction Synchronization Registry lookup directly using an instance of TransactionManagerLookup.
transactionSynchronizationRegistryLookup() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Configure Transaction Synchronization Registry lookup directly using an instance of TransactionManagerLookup.
transactionSynchronizationRegistryLookup(TransactionSynchronizationRegistryLookup) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Configure Transaction Synchronization Registry lookup directly using an instance of TransactionManagerLookup.
TransactionSynchronizationRegistryLookup - Interface in org.infinispan.transaction.lookup
 
transactionTable - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
transactionTable - Variable in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
TransactionTable - Class in org.infinispan.transaction
Repository for RemoteTransaction and TransactionXaAdapters (locally originated transactions).
TransactionTable() - Constructor for class org.infinispan.transaction.TransactionTable
 
TransactionTableFactory - Class in org.infinispan.factories
Factory for TransactionTable objects.
TransactionTableFactory() - Constructor for class org.infinispan.factories.TransactionTableFactory
 
TransactionXaAdapter - Class in org.infinispan.transaction.xa
This acts both as an local CacheTransaction and implementor of an XAResource that will be called by tx manager on various tx stages.
TransactionXaAdapter(LocalXaTransaction, TransactionTable, RecoveryManager, TransactionCoordinator, CommandsFactory, RpcManager, ClusteringDependentLogic, Configuration) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
TransactionXaAdapter(TransactionTable, RecoveryManager, TransactionCoordinator, CommandsFactory, RpcManager, ClusteringDependentLogic, Configuration) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
transform(E) - Method in interface org.infinispan.util.InfinispanCollections.Function
Transforms an instance of the given input into an instace of the type to be returned.
transform(E) - Method in interface org.infinispan.util.InfinispanCollections.MapMakerFunction
Transforms the given input into a key/value pair for use in a map
Transformable - Annotation Type in org.infinispan.query
If you annotate your object with this, it can be used as a valid key for Infinispan to index.
transformCollectionToMap(Collection<E>, InfinispanCollections.MapMakerFunction<K, V, E>) - Static method in class org.infinispan.util.InfinispanCollections
Given a collection, transforms the collection to a map given a InfinispanCollections.MapMakerFunction
Transformer - Interface in org.infinispan.query
The task of this interface is to convert keys from their original types to a String representation (which can be used in Lucene) and vice versa.
transformForL1(CacheEntry) - Method in interface org.infinispan.distribution.DistributionManager
Transforms a cache entry so it is marked for L1 rather than the primary cache data structure.
transformForL1(CacheEntry) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
transformMapValue(Map<K, E>, InfinispanCollections.Function<E, V>) - Static method in class org.infinispan.util.InfinispanCollections
Given a map of well known key/value types, it makes a shallow copy of it while at the same time transforming it's value type to a desired output type.
TRANSIENT_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
TRANSIENT_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
TransientCacheEntry - Class in org.infinispan.container.entries
A cache entry that is transient, i.e., it can be considered expired after a period of not being used.
TransientCacheEntry(Object, TransientCacheValue) - Constructor for class org.infinispan.container.entries.TransientCacheEntry
 
TransientCacheEntry(Object, Object, long) - Constructor for class org.infinispan.container.entries.TransientCacheEntry
 
TransientCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheEntry
 
TransientCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
TransientCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
TransientCacheValue - Class in org.infinispan.container.entries
A transient cache value, to correspond with TransientCacheEntry
TransientCacheValue(Object, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheValue
 
TransientCacheValue.Externalizer - Class in org.infinispan.container.entries
 
TransientCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
TransientMortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is both transient and mortal.
TransientMortalCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
 
TransientMortalCacheEntry(Object, Object) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
 
TransientMortalCacheEntry(Object, TransientMortalCacheValue) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
 
TransientMortalCacheEntry(Object, Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
 
TransientMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
TransientMortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
TransientMortalCacheValue - Class in org.infinispan.container.entries
A transient, mortal cache value to correspond with TransientMortalCacheEntry
TransientMortalCacheValue(Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue(Object, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue(Object, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
TransientMortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
Transport - Interface in org.infinispan.client.hotrod.impl.transport
Transport abstraction.
transport() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
transport() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
transport() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
transport() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
transport(Transport) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Class that represents a network transport.
Transport - Interface in org.infinispan.remoting.transport
An interface that provides a communication link with remote caches.
Transport - Interface in org.infinispan.server.core.transport
Server transport abstraction
TRANSPORT_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
transportClass(Class<? extends Transport>) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. Class that represents a network transport.
transportClass - Variable in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
transportClass(Class<? extends Transport>) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
TransportConfiguration - Class in org.infinispan.configuration.global
 
TransportConfigurationBuilder - Class in org.infinispan.configuration.global
Configures the transport used for network communications across the cluster.
TransportException - Exception in org.infinispan.client.hotrod.exceptions
Indicates a communication exception with the Hot Rod server: e.g.
TransportException() - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
transportFactory - Variable in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
TransportFactory - Interface in org.infinispan.client.hotrod.impl.transport
Transport factory for building and managing Transport objects.
TransportFactory - Class in org.infinispan.factories
Factory for Transport implementations
TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
 
TransportObjectFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
TransportObjectFactory(Codec, TcpTransportFactory, AtomicInteger, boolean) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
TreeCache<K,V> - Interface in org.infinispan.tree
This is a tree-like facade around a Cache allowing for efficient tree-style access to cached data.
TreeCacheFactory - Class in org.infinispan.tree
Factory class that contains API for users to create instances of TreeCache
TreeCacheFactory() - Constructor for class org.infinispan.tree.TreeCacheFactory
 
TreeCacheImpl<K,V> - Class in org.infinispan.tree
 
TreeCacheImpl(Cache<?, ?>) - Constructor for class org.infinispan.tree.TreeCacheImpl
 
TreeCacheImpl(AdvancedCache<?, ?>) - Constructor for class org.infinispan.tree.TreeCacheImpl
 
TreeContext - Class in org.infinispan.tree
Tree invocation context primarily used to hold flags that should be set for all cache operations within a single tree cache operation.
TreeContext() - Constructor for class org.infinispan.tree.TreeContext
 
TreeNode - Class in org.infinispan.tools.schema
TreeNode of Infinispan configuration
TreeNode(String, TreeNode) - Constructor for class org.infinispan.tools.schema.TreeNode
 
TreeNode() - Constructor for class org.infinispan.tools.schema.TreeNode
 
TreeStructureSupport - Class in org.infinispan.tree
 
TreeStructureSupport(AdvancedCache<?, ?>, BatchContainer) - Constructor for class org.infinispan.tree.TreeStructureSupport
 
TreeWalker - Interface in org.infinispan.tools.schema
TreeWalker visitor
tryAcquire(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
tryingToFetchState(Address) - Method in interface org.infinispan.util.logging.Log
 
tryLock(L, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
 
tryLock(OwnableReentrantLock, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
tryLock(OwnableReentrantLock, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
tryLock(ReentrantLock, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
tryLock(ReentrantLock, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
tryLock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryLock(long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryLock(Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryRelease(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryReleaseShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
TwoWayKey2StringMapper - Interface in org.infinispan.loaders.keymappers
Extends Key2StringMapper and allows a bidirectional transformation between keys and Strings.
tx - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
TxCompletionNotificationCommand - Class in org.infinispan.commands.remote.recovery
Command for removing recovery related information from the cluster.
TxCompletionNotificationCommand(Xid, GlobalTransaction, String) - Constructor for class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
TxCompletionNotificationCommand(long, String) - Constructor for class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
TxCompletionNotificationCommand(String) - Constructor for class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
txCoordinator - Variable in class org.infinispan.interceptors.TxInterceptor
 
txCoordinator - Variable in class org.infinispan.transaction.TransactionTable
 
txFactory - Variable in class org.infinispan.transaction.TransactionTable
 
TxInterceptor - Class in org.infinispan.interceptors
Interceptor in charge with handling transaction related operations, e.g enlisting cache as an transaction participant, propagating remotely initiated changes.
TxInterceptor() - Constructor for class org.infinispan.interceptors.TxInterceptor
 
TxInvocationContext - Interface in org.infinispan.context.impl
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
txMarker(byte) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
txMods - Variable in class org.infinispan.interceptors.InvalidationInterceptor
 
txTable - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
txTable - Variable in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
type - Variable in class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
TypedProperties - Class in org.infinispan.client.hotrod.impl
Type-aware properties.
TypedProperties(Properties) - Constructor for class org.infinispan.client.hotrod.impl.TypedProperties
Copy constructor
TypedProperties() - Constructor for class org.infinispan.client.hotrod.impl.TypedProperties
Default constructor that returns an empty instance
TypedProperties - Class in org.infinispan.util
Type-aware properties.
TypedProperties(Properties) - Constructor for class org.infinispan.util.TypedProperties
Copy constructor
TypedProperties() - Constructor for class org.infinispan.util.TypedProperties
Default constructor that returns an empty instance
TypedPropertiesAdapter - Class in org.infinispan.config
TypedPropertiesAdapter is JAXB XmlAdapter for TypedProperties.
TypedPropertiesAdapter() - Constructor for class org.infinispan.config.TypedPropertiesAdapter
 

U

uc(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Safely converts a String to upper case.
uc(String) - Method in class org.infinispan.config.CustomInterceptorConfig
 
unableToAcquireLockToPurgeStore() - Method in interface org.infinispan.util.logging.Log
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToClearAsyncStore() - Method in interface org.infinispan.util.logging.Log
 
unableToCommitTransaction(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
unableToConfigureCloudService(String, String, Set<?>) - Method in interface org.infinispan.loaders.cloud.logging.Log
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToInt(String, int) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToConvertStringPropertyToInt(String, int) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToLong(String, long) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToConvertStringPropertyToLong(String, long) - Method in interface org.infinispan.util.logging.Log
 
unableToCopyEntryForUpdate(Object) - Method in interface org.infinispan.util.logging.Log
 
unableToInstantiateCacheKeyGenerator(Class<?>, Throwable) - Method in interface org.infinispan.cdi.util.logging.Log
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in interface org.infinispan.util.logging.Log
 
unableToLoadFromCacheLoader(Object, CacheLoaderException) - Method in interface org.infinispan.util.logging.Log
 
unableToLockToInvalidate(Object, Address) - Method in interface org.infinispan.util.logging.Log
 
unableToPassivateEntry(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToProcessAsyncModifications(int) - Method in interface org.infinispan.util.logging.Log
 
unableToProcessLeaver(Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToReadBlob(String, CacheLoaderException) - Method in interface org.infinispan.loaders.cloud.logging.Log
 
unableToReadVersionId() - Method in interface org.infinispan.util.logging.Log
 
unableToRetrieveState(Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToSetValue(Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToStartTransaction(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
unableToStopTransactionLogging(IllegalMonitorStateException) - Method in interface org.infinispan.util.logging.Log
 
unableToUnlockRebalancedKeys(GlobalTransaction, List<Object>, Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in interface org.infinispan.util.logging.Log
 
unableToUnwrapProviderImplementation(Class<?>) - Method in interface org.infinispan.cdi.util.logging.Log
 
unableToUpdateView() - Method in interface org.infinispan.server.hotrod.logging.JavaLog
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in interface org.infinispan.util.logging.Log
 
unbindingDummyTmFailed(NamingException) - Method in interface org.infinispan.util.logging.Log
 
unblock() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
unblockNewTransactions(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
unblockNewTransactions(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
UNBOUNDED - Static variable in interface org.infinispan.context.InvocationContextContainer
To be used when building InvocationContext with InvocationContextContainer.createInvocationContext(boolean, int) as an indicator of the fact that the size of the keys to be accessed in the context is not known.
unBoundedDataContainer(int) - Static method in class org.infinispan.container.DefaultDataContainer
 
UnclosableObjectInputStream - Class in org.infinispan.io
A delegating ObjectInput that delegates all methods except ObjectInput.close().
UnclosableObjectInputStream(ObjectInput) - Constructor for class org.infinispan.io.UnclosableObjectInputStream
 
UnclosableObjectOutputStream - Class in org.infinispan.io
An unclosable version of an ObjectOutput.
UnclosableObjectOutputStream(ObjectOutput) - Constructor for class org.infinispan.io.UnclosableObjectOutputStream
 
uncommittedChanges - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
undelete(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
undelete(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
If the entry is marked as removed and doUndelete==true then the "valid" flag is set to true and "removed" flag is set to false.
undelete(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
undelete(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
unexpectedAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an unexpected XML attribute.
unexpectedClassNotFoundException(ClassNotFoundException) - Method in interface org.infinispan.loaders.jdbc.logging.Log
 
unexpectedElement(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an unexpected XML element.
unexpectedEndElement(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an unexpected end tag for an XML element.
unexpectedErrorFromResourceManager(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorReplicating(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedNumberRecordsWritten(long, int) - Method in interface org.infinispan.loaders.bdbje.logging.Log
 
unfinishedTransactionsRemain(int, int) - Method in interface org.infinispan.util.logging.Log
 
UNION_CONSISTENT_HASH - Static variable in interface org.infinispan.marshall.Ids
 
UnionConsistentHash - Class in org.infinispan.distribution.ch
A delegating wrapper that locates keys by getting a union of locations reported by two other ConsistentHash implementations it delegates to.
UnionConsistentHash(ConsistentHash, ConsistentHash) - Constructor for class org.infinispan.distribution.ch.UnionConsistentHash
 
UnionConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
UnionConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.ch.UnionConsistentHash.Externalizer
 
UNKNOWN_COMMAND_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
UNKNOWN_VERSION_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
unknownResponsesFromRemoteCache(Collection<Response>) - Method in interface org.infinispan.util.logging.Log
 
unlock(L) - Method in class org.infinispan.loaders.LockSupportCacheStore
Release the locks (either read or write).
unlock(L, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
 
unlock(OwnableReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
unlock(OwnableReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
unlock(ReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
unlock(ReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
unlock(Collection<Object>, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases the lock passed in.
unlock(Collection<Object>, Object) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
unlock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
unlock(Object) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
unlockAll(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases locks present in an invocation context and transaction entry, if one is available.
unlockAll(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
unmarshal(Configuration.ClusteringType) - Method in class org.infinispan.config.Configuration.ClusteringTypeAdapter
Deprecated.  
unmarshal(PropertiesType) - Method in class org.infinispan.config.TypedPropertiesAdapter
 
unmarshall(StreamingMarshaller, InputStream) - Static method in class org.infinispan.loaders.jdbc.JdbcUtil
 
UnmarshalledReferences - Class in org.infinispan.marshall
An efficient array-based list of referenced objects, using the reference id as a subscript for the array.
UnmarshalledReferences() - Constructor for class org.infinispan.marshall.UnmarshalledReferences
 
unmarshallMap(Map<Object, Object>, ObjectInput) - Static method in class org.infinispan.marshall.MarshallUtil
 
unprocessedTxLogEntries(int) - Method in interface org.infinispan.util.logging.Log
 
unregisterCacheMBean() - Method in class org.infinispan.jmx.CacheJmxRegistration
 
unregisterConfiguration(String) - Method in interface org.infinispan.config.ConfigurationRegistry
Unregisters the named configuration.
unregisterMBean(ObjectName, MBeanServer) - Static method in class org.infinispan.jmx.JmxUtil
Unregister the MBean located under the given ObjectName
unregisterMBeans(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
unregisterMBeans() - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Unregisters all the MBeans registered through ComponentsJmxRegistration.registerMBeans().
unregisterNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
unreliableReturnValues - Variable in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
unreliableReturnValues(Boolean) - Method in class org.infinispan.config.Configuration.UnsafeType
Deprecated.  
unreliableReturnValues(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.UnsafeConfig
Deprecated.  
unreliableReturnValues() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
Specifies whether Infinispan is allowed to disregard the Map contract when providing return values for Map.put(Object, Object) and Map.remove(Object) methods.
unreliableReturnValues(boolean) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
Specify whether Infinispan is allowed to disregard the Map contract when providing return values for Map.put(Object, Object) and Map.remove(Object) methods.
unsafe() - Method in class org.infinispan.configuration.cache.Configuration
 
unsafe() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
unsafe() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
UnsafeConfiguration - Class in org.infinispan.configuration.cache
Controls certain tuning parameters that may break some of Infinispan's public API contracts in exchange for better performance in some cases.
UnsafeConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls certain tuning parameters that may break some of Infinispan's public API contracts in exchange for better performance in some cases.
UnsafeConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
unsetContextFlag(AbstractInvocationContext.ContextFlag) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Utility method that un-sets a context flag.
unsetCurrentRequestor() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
unsetFlag(DeltaAwareCacheEntry.Flags) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
Utility method that sets the value of the flag to false.
unsetFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Utility method that sets the value of the flag to false.
UnsignedNumeric - Class in org.infinispan.io
Helper to read and write unsigned numerics
UnsignedNumeric() - Constructor for class org.infinispan.io.UnsignedNumeric
 
unstartedRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.logging.Log
 
UNSUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
UnsuccessfulResponse - Class in org.infinispan.remoting.responses
An unsuccessful response
UnsuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
UnsuccessfulResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
UnsupportedKeyTypeException - Exception in org.infinispan.loaders.keymappers
Exception thrown by certain cache stores when one tries to persist an entry with an unsupported key type.
UnsupportedKeyTypeException(Object) - Constructor for exception org.infinispan.loaders.keymappers.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String) - Constructor for exception org.infinispan.loaders.keymappers.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String, Throwable) - Constructor for exception org.infinispan.loaders.keymappers.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(Throwable) - Constructor for exception org.infinispan.loaders.keymappers.UnsupportedKeyTypeException
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in interface org.infinispan.util.logging.Log
 
UNSURE_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
UnsureResponse - Class in org.infinispan.remoting.responses
An unsure response - used with Dist - essentially asks the caller to check the next response from the next node since the sender is in a state of flux (probably in the middle of rebalancing)
UnsureResponse() - Constructor for class org.infinispan.remoting.responses.UnsureResponse
 
UnsureResponse.Externalizer - Class in org.infinispan.remoting.responses
 
UnsureResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
unwrap(Class<T>) - Method in class org.infinispan.cdi.interceptor.context.CacheKeyInvocationContextImpl
 
update(InternalCacheEntry, long, long) - Method in interface org.infinispan.container.InternalEntryFactory
Updates an existing InternalCacheEntry with new lifespan and maxIdle values.
update(InternalCacheEntry, long, long) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
update(InternalCacheEntry, long, long) - Method in class org.infinispan.container.VersionedInternalEntryFactoryImpl
 
update() - Method in class org.infinispan.demo.InfinispanDemo.CachedDataTableModel
 
updateBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Updates a bucket in the store with the Bucket passed in to the method.
updateBucket(Bucket) - Method in class org.infinispan.loaders.cloud.CloudCacheStore
 
updateBucket(Bucket) - Method in class org.infinispan.loaders.file.FileCacheStore
 
updateBucket(Bucket) - Method in class org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore
 
updateDomain(ComponentsJmxRegistration, GlobalComponentRegistry, MBeanServer, String) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
updateDomain(ComponentsJmxRegistration, MBeanServer, String) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
updateHashFunction(Map<SocketAddress, Set<Integer>>, int, short, int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
updateHashFunction(Map<SocketAddress, Set<Integer>>, int, short, int) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
updateIndexes(Object, Object) - Method in class org.infinispan.query.backend.QueryInterceptor
 
updateLatestViewId(int) - Method in class org.infinispan.cacheviews.PendingCacheViewChanges
If we recovered a view after a merge or coordinator change we need to make sure the next view id is greater than any view id that was already committed.
updateServers(Collection<SocketAddress>) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
updateServers(Collection<SocketAddress>) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
updateStateOnNodesLeaving(Collection<Address>) - Method in class org.infinispan.transaction.TransactionTable
 
updateStateOnNodesLeaving(Collection<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
First moves the prepared transactions originated on the leavers into the recovery cache and then cleans up the transactions that are not yet prepared.
upgradeLock(L) - Method in class org.infinispan.loaders.LockSupportCacheStore
Upgrades a read lock to a write lock.
upgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.  
use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated. Please refer to Configuration.isUse1PcForAutoCommitTransactions().
use1PcForAutoCommitTransactions(boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated. This configuration option was added for the following situation: - pre 5.1 code is using the cache
use1PcForAutoCommitTransactions() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Before Infinispan 5.1 you could access the cache both transactionally and non-transactionally.
use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Before Infinispan 5.1 you could access the cache both transactionally and non-transactionally.
useEagerLocking - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
useEagerLocking(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
useEagerLocking(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated.  
useEagerLocking() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated. 
useEagerLocking(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated. 
useEagerLocking(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Deprecated. 
useLockStriping - Variable in class org.infinispan.config.Configuration.LockingType
Deprecated.  
useLockStriping(Boolean) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
useLockStriping(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.LockingConfig
Deprecated. If true, a pool of shared locks is maintained for all entries that need to be locked.
useLockStriping() - Method in class org.infinispan.configuration.cache.LockingConfiguration
If true, a pool of shared locks is maintained for all entries that need to be locked.
useLockStriping(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
If true, a pool of shared locks is maintained for all entries that need to be locked.
useRepeatableRead - Variable in class org.infinispan.container.EntryFactoryImpl
 
useReplQueue - Variable in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
useReplQueue(Boolean) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
useReplQueue(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.AsyncConfig
Deprecated. If true, this forces all async communications to be queued up and sent out periodically as a batch.
useReplQueue() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
If true, this forces all async communications to be queued up and sent out periodically as a batch.
useReplQueue(boolean) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
If true, forces all async communications to be queued up and sent out periodically as a batch.
useSynchronization - Variable in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
useSynchronization(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
useSynchronization(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.TransactionConfig
Deprecated.  
useSynchronization() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
useSynchronization(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Configures whether the cache registers a synchronization with the transaction manager, or registers itself as an XA resource.
usingAsyncStore() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
usingBatchModeTransactionManager() - Method in interface org.infinispan.util.logging.Log
 
usingCacheLoaders() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
usingChainingCacheLoader() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
usingChainingCacheLoader() - Method in class org.infinispan.configuration.cache.LoadersConfiguration
 
Util - Class in org.infinispan.util
General utility methods used throughout the Infinispan code base.

V

validate() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
validateObject(Object, Object) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
This will be called by the test thread when testWhileIdle==true.
VALIDATING_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
validOptions(String[][], DocErrorReporter) - Static method in class org.infinispan.tools.doclet.config.ConfigDoclet
 
validOptions(String[][], DocErrorReporter) - Static method in class org.infinispan.tools.doclet.jmx.JmxDoclet
 
validOptions(String[][], DocErrorReporter) - Static method in class org.infinispan.tools.rhq.RhqPluginXmlGenerator
 
ValidResponse - Class in org.infinispan.remoting.responses
A valid response
ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
 
value - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
value - Variable in class org.infinispan.commands.write.RemoveCommand
When not null, value indicates that the entry should only be removed if the key is mapped to this value.
value - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
value - Variable in class org.infinispan.container.entries.ImmortalCacheValue
 
value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
VALUE - Static variable in interface org.infinispan.server.websocket.OpHandler
 
VALUE_SIZE_ESTIMATE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
valueOf(String) - Static method in enum org.infinispan.atomic.NullDelta
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.impl.operations.PingOperation.PingResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.commands.control.CacheViewControlCommand.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.commands.control.StateTransferControlCommand.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.config.Configuration.CacheMode
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder.FsyncMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.VersioningScheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.global.ShutdownHookBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Element
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Namespace
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.container.entries.DeltaAwareCacheEntry.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.context.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.context.impl.AbstractInvocationContext.ContextFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.distribution.DataLocality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.eviction.EvictionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.eviction.EvictionThreadPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.factories.scopes.Scopes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.lifecycle.ComponentStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.loaders.file.FileCacheStoreConfig.FsyncMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.loaders.jdbc.DatabaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.loaders.modifications.Modification.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.server.core.DecoderState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.transaction.LockingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.transaction.TransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.tree.NodeKey.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.concurrent.BoundedConcurrentHashMap.Eviction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns the enum constant of this type with the specified name.
values() - Method in class org.infinispan.AbstractDelegatingCache
 
values() - Method in class org.infinispan.atomic.AtomicHashMap
 
values() - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
values() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
values() - Static method in enum org.infinispan.atomic.NullDelta
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.Cache
Returns a collection view of the values contained in this cache.
values() - Method in class org.infinispan.CacheImpl
 
values() - Static method in enum org.infinispan.client.hotrod.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.client.hotrod.impl.operations.PingOperation.PingResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
values() - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
values() - Static method in enum org.infinispan.commands.control.CacheViewControlCommand.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.commands.control.StateTransferControlCommand.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.config.Configuration.CacheMode
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.config.GlobalConfiguration.ShutdownHookBehavior
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.cache.CacheMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder.FsyncMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.cache.VersioningScheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.global.ShutdownHookBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.Attribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.Element
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.Namespace
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.container.DataContainer
 
values() - Method in class org.infinispan.container.DefaultDataContainer
 
values() - Static method in enum org.infinispan.container.entries.DeltaAwareCacheEntry.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.context.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.context.impl.AbstractInvocationContext.ContextFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.DecoratedCache
 
values() - Static method in enum org.infinispan.distribution.DataLocality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.eviction.EvictionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.eviction.EvictionThreadPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.factories.scopes.Scopes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.lifecycle.ComponentStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.loaders.file.FileCacheStoreConfig.FsyncMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.loaders.jdbc.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.loaders.modifications.Modification.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.server.core.DecoderState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.transaction.LockingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.transaction.TransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.tree.NodeKey.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.infinispan.util.AbstractMap
 
values() - Static method in enum org.infinispan.util.concurrent.BoundedConcurrentHashMap.Eviction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Collection view of the values contained in this map.
values() - Method in class org.infinispan.util.concurrent.ConcurrentWeakKeyHashMap
Returns a Collection view of the values contained in this map.
values() - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a Collection view of the values contained in this map.
values() - Method in class org.infinispan.util.FastCopyHashMap
 
ValuesCommand - Class in org.infinispan.commands.read
Command implementation for Map.values() functionality.
ValuesCommand(DataContainer) - Constructor for class org.infinispan.commands.read.ValuesCommand
 
ValuesCommand.ExpiredFilteredValues - Class in org.infinispan.commands.read
 
ValuesCommand.ExpiredFilteredValues(Set<InternalCacheEntry>) - Constructor for class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
version(String) - Method in interface org.infinispan.cdi.util.logging.Log
 
Version - Class in org.infinispan.cdi.util
 
Version() - Constructor for class org.infinispan.cdi.util.Version
 
Version - Class in org.infinispan.client.hotrod
Defines client and protocol version.
Version() - Constructor for class org.infinispan.client.hotrod.Version
 
version(String) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated. Largest allowable version to use when marshalling internal state.
version(short) - Method in interface org.infinispan.config.FluentGlobalConfiguration.SerializationConfig
Deprecated.  
version - Variable in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
version(String) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
version(short) - Method in class org.infinispan.config.GlobalConfiguration.SerializationType
Deprecated.  
version() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
version(short) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Largest allowable version to use when marshalling internal state.
version(String) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Largest allowable version to use when marshalling internal state.
version(String) - Method in interface org.infinispan.util.logging.Log
 
Version - Class in org.infinispan
Contains version information about this release of Infinispan.
Version() - Constructor for class org.infinispan.Version
 
VERSION - Static variable in class org.infinispan.Version
 
VERSION_10 - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
VERSION_11 - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
VERSION_ID - Static variable in class org.infinispan.Version
 
VersionAwareMarshaller - Class in org.infinispan.marshall
A delegate to various other marshallers like JBossMarshaller.
VersionAwareMarshaller() - Constructor for class org.infinispan.marshall.VersionAwareMarshaller
 
Versioned - Interface in org.infinispan.container.entries.versioned
An interface that marks the ability to handle versions
VERSIONED_IMMORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_IMMORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_TRANSIENT_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
VERSIONED_TRANSIENT_VALUE - Static variable in interface org.infinispan.marshall.Ids
 
VersionedCommitCommand - Class in org.infinispan.commands.tx
The same as a CommitCommand except that version information is also carried by this command, used by optimistically transactional caches making use of write skew checking when using IsolationLevel.REPEATABLE_READ.
VersionedCommitCommand() - Constructor for class org.infinispan.commands.tx.VersionedCommitCommand
 
VersionedCommitCommand(String, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.VersionedCommitCommand
 
VersionedCommitCommand(String) - Constructor for class org.infinispan.commands.tx.VersionedCommitCommand
 
VersionedDistributionInterceptor - Class in org.infinispan.interceptors
A version of the DistributionInterceptor that adds logic to handling prepares when entries are versioned.
VersionedDistributionInterceptor() - Constructor for class org.infinispan.interceptors.VersionedDistributionInterceptor
 
VersionedEntryWrappingInterceptor - Class in org.infinispan.interceptors
Interceptor in charge with wrapping entries and add them in caller's context.
VersionedEntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
VersionedImmortalCacheEntry - Class in org.infinispan.container.entries.versioned
A form of ImmortalCacheEntry that is Versioned
VersionedImmortalCacheEntry(Object, Object, EntryVersion) - Constructor for class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry
 
VersionedImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedImmortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry.Externalizer
 
VersionedImmortalCacheValue - Class in org.infinispan.container.entries.versioned
A form of ImmortalCacheValue that is Versioned
VersionedImmortalCacheValue(Object, EntryVersion) - Constructor for class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue
 
VersionedImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedImmortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue.Externalizer
 
VersionedInternalEntryFactoryImpl - Class in org.infinispan.container
An implementation that generates versioned entries
VersionedInternalEntryFactoryImpl() - Constructor for class org.infinispan.container.VersionedInternalEntryFactoryImpl
 
VersionedMortalCacheEntry - Class in org.infinispan.container.entries.versioned
A form of MortalCacheEntry that is Versioned
VersionedMortalCacheEntry(Object, Object, EntryVersion, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry
 
VersionedMortalCacheEntry(Object, Object, EntryVersion, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry
 
VersionedMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedMortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry.Externalizer
 
VersionedMortalCacheValue - Class in org.infinispan.container.entries.versioned
A form of MortalCacheValue that is Versioned
VersionedMortalCacheValue(Object, EntryVersion, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedMortalCacheValue
 
VersionedMortalCacheValue.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedMortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedMortalCacheValue.Externalizer
 
VersionedOperationResponse - Class in org.infinispan.client.hotrod.impl
 
VersionedOperationResponse(byte[], VersionedOperationResponse.RspCode) - Constructor for class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
VersionedOperationResponse.RspCode - Enum in org.infinispan.client.hotrod.impl
 
VersionedPrepareCommand - Class in org.infinispan.commands.tx
Same as PrepareCommand except that the transaction originator makes evident the versions of entries touched and stored in a transaction context so that accurate write skew checks may be performed by the lock owner(s).
VersionedPrepareCommand() - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedPrepareCommand(String, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedPrepareCommand(String) - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedPutKeyValueCommand - Class in org.infinispan.commands.write
A form of PutKeyValueCommand that also applies a version to the entry created.
VersionedPutKeyValueCommand() - Constructor for class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
VersionedPutKeyValueCommand(Object, Object, boolean, CacheNotifier, long, long, Set<Flag>, EntryVersion) - Constructor for class org.infinispan.commands.write.VersionedPutKeyValueCommand
 
VersionedReplicationInterceptor - Class in org.infinispan.interceptors
A form of the ReplicationInterceptor that adds additional logic to how prepares are handled.
VersionedReplicationInterceptor() - Constructor for class org.infinispan.interceptors.VersionedReplicationInterceptor
 
VersionedTransientCacheEntry - Class in org.infinispan.container.entries.versioned
A form of TransientCacheEntry that is Versioned
VersionedTransientCacheEntry(Object, Object, EntryVersion, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry
 
VersionedTransientCacheEntry(Object, Object, EntryVersion, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry
 
VersionedTransientCacheEntry.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedTransientCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry.Externalizer
 
VersionedTransientCacheValue - Class in org.infinispan.container.entries.versioned
A form of TransientCacheValue that is Versioned
VersionedTransientCacheValue(Object, EntryVersion, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientCacheValue
 
VersionedTransientCacheValue.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedTransientCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientCacheValue.Externalizer
 
VersionedTransientMortalCacheEntry - Class in org.infinispan.container.entries.versioned
A form of TransientMortalCacheEntry that is Versioned
VersionedTransientMortalCacheEntry(Object, Object, EntryVersion, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry
 
VersionedTransientMortalCacheEntry(Object, Object, EntryVersion, long, long, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry
 
VersionedTransientMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedTransientMortalCacheEntry.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry.Externalizer
 
VersionedTransientMortalCacheValue - Class in org.infinispan.container.entries.versioned
A form of TransientMortalCacheValue that is Versioned
VersionedTransientMortalCacheValue(Object, EntryVersion, long, long, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue
 
VersionedTransientMortalCacheValue(Object, EntryVersion, long, long, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue
 
VersionedTransientMortalCacheValue(Object, EntryVersion, long) - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue
 
VersionedTransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries.versioned
 
VersionedTransientMortalCacheValue.Externalizer() - Constructor for class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue.Externalizer
 
VersionedValue<V> - Interface in org.infinispan.client.hotrod
Besides the key and value, also contains an version.
VersionedValueImpl<V> - Class in org.infinispan.client.hotrod.impl
 
VersionedValueImpl(long, V) - Constructor for class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
VersionGenerator - Interface in org.infinispan.container.versioning
Generates versions
versioning() - Method in class org.infinispan.configuration.cache.Configuration
 
versioning() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
versioning() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
VersioningConfiguration - Class in org.infinispan.configuration.cache
This configuration element controls whether entries are versioned.
VersioningConfigurationBuilder - Class in org.infinispan.configuration.cache
 
VersioningConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
VersioningMetaFactory - Class in org.infinispan.factories
 
VersioningMetaFactory() - Constructor for class org.infinispan.factories.VersioningMetaFactory
 
versioningScheme - Variable in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
versioningScheme(VersioningScheme) - Method in class org.infinispan.config.Configuration.VersioningConfigurationBean
Deprecated.  
versioningScheme(VersioningScheme) - Method in interface org.infinispan.config.FluentConfiguration.VersioningConfig
Deprecated.  
VersioningScheme - Enum in org.infinispan.configuration.cache
The various versioning schemes supported
viewAccepted(View) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
viewChange(ViewChangedEvent) - Method in class org.infinispan.loaders.decorators.SingletonStore.SingletonStoreListener
The cluster formation changed, so determine whether the current cache stopped being the coordinator or became the coordinator.
ViewChanged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology changes (i.e., a member joins or leaves the cluster).
ViewChangedAdapter - Class in org.infinispan.cdi.event.cachemanager
 
ViewChangedAdapter(Event<ViewChangedEvent>) - Constructor for class org.infinispan.cdi.event.cachemanager.ViewChangedAdapter
 
viewChangeDetected(List<Address>, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
ViewChangedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with ViewChanged.
viewChangeEvent(ViewChangedEvent) - Method in class org.infinispan.demo.InfinispanDemo.CacheListener
 
viewChangeInterrupted() - Method in interface org.infinispan.util.logging.Log
 
viewInstallationFailure(Throwable, String) - Method in interface org.infinispan.util.logging.Log
 
viewNullWhileDetectingCrashedMember() - Method in interface org.infinispan.server.hotrod.logging.JavaLog
 
VirtualAddress - Class in org.infinispan.distribution.ch
Virtual addresses are used internally by the consistent hashes in order to provide virtual nodes.
VirtualAddress(Address, int) - Constructor for class org.infinispan.distribution.ch.VirtualAddress
 
VisitableCommand - Interface in org.infinispan.commands
A type of command that can accept Visitors, such as CommandInterceptors.
visitAdvancedExternalizerConfig(AdvancedExternalizerConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitAdvancedExternalizerConfig(AdvancedExternalizerConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitAdvancedExternalizerConfig(AdvancedExternalizerConfig) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitAdvancedExternalizersType(GlobalConfiguration.AdvancedExternalizersType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitAdvancedExternalizersType(GlobalConfiguration.AdvancedExternalizersType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitAdvancedExternalizersType(GlobalConfiguration.AdvancedExternalizersType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in interface org.infinispan.commands.Visitor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitAsyncStoreConfig(AsyncStoreConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.config.TimeoutConfigurationValidatingVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitAsyncType(Configuration.AsyncType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitBooleanAttributeType(Configuration.BooleanAttributeType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitCacheLoaderConfig(CacheLoaderConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCacheLoaderConfig(CacheLoaderConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCacheLoaderConfig(CacheLoaderConfig) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitCacheLoaderManagerConfig(CacheLoaderManagerConfig) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in interface org.infinispan.commands.Visitor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitClusteringType(Configuration.ClusteringType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitClusteringType(Configuration.ClusteringType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitClusteringType(Configuration.ClusteringType) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitClusteringType(Configuration.ClusteringType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitClusteringType(Configuration.ClusteringType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitCollection(InvocationContext, Collection<? extends VisitableCommand>) - Method in class org.infinispan.commands.AbstractVisitor
Helper method to visit a collection of VisitableCommands.
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in interface org.infinispan.commands.Visitor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
visitConfiguration(Configuration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitConfiguration(Configuration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitConfiguration(Configuration) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitConfiguration(Configuration) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitConfiguration(Configuration) - Method in class org.infinispan.config.TimeoutConfigurationValidatingVisitor
 
visitCustomInterceptorConfig(CustomInterceptorConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCustomInterceptorConfig(CustomInterceptorConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCustomInterceptorConfig(CustomInterceptorConfig) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitCustomInterceptorsType(Configuration.CustomInterceptorsType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitDataContainerType(Configuration.DataContainerType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitDataContainerType(Configuration.DataContainerType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitDataContainerType(Configuration.DataContainerType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitDataContainerType(Configuration.DataContainerType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitDeadlockDetectionType(Configuration.DeadlockDetectionType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitDistributedExecuteCommand(InvocationContext, DistributedExecuteCommand<?>) - Method in class org.infinispan.commands.AbstractVisitor
 
visitDistributedExecuteCommand(InvocationContext, DistributedExecuteCommand<?>) - Method in interface org.infinispan.commands.Visitor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in interface org.infinispan.commands.Visitor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in interface org.infinispan.commands.Visitor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
visitEvictionType(Configuration.EvictionType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitEvictionType(Configuration.EvictionType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitEvictionType(Configuration.EvictionType) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitEvictionType(Configuration.EvictionType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitEvictionType(Configuration.EvictionType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitExpirationType(Configuration.ExpirationType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitFactoryClassWithPropertiesType(GlobalConfiguration.FactoryClassWithPropertiesType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitFactoryClassWithPropertiesType(GlobalConfiguration.FactoryClassWithPropertiesType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitFactoryClassWithPropertiesType(GlobalConfiguration.FactoryClassWithPropertiesType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitGlobalConfiguration(GlobalConfiguration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.TimeoutConfigurationValidatingVisitor
 
visitGlobalJmxStatisticsType(GlobalConfiguration.GlobalJmxStatisticsType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitGlobalJmxStatisticsType(GlobalConfiguration.GlobalJmxStatisticsType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitGlobalJmxStatisticsType(GlobalConfiguration.GlobalJmxStatisticsType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitGroupConfig(GroupsConfiguration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitGroupConfig(GroupsConfiguration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitGroupConfig(GroupsConfiguration) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitGroupConfig(GroupsConfiguration) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitHashType(Configuration.HashType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitHashType(Configuration.HashType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitHashType(Configuration.HashType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitHashType(Configuration.HashType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitInfinispanConfiguration(InfinispanConfiguration) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitInfinispanConfiguration(InfinispanConfiguration) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitInfinispanConfiguration(InfinispanConfiguration) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in interface org.infinispan.commands.Visitor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.commands.AbstractVisitor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in interface org.infinispan.commands.Visitor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in interface org.infinispan.commands.Visitor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitL1Type(Configuration.L1Type) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitL1Type(Configuration.L1Type) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitL1Type(Configuration.L1Type) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitL1Type(Configuration.L1Type) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitL1Type(Configuration.L1Type) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in interface org.infinispan.commands.Visitor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitLockingType(Configuration.LockingType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitLockingType(Configuration.LockingType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitLockingType(Configuration.LockingType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitLockingType(Configuration.LockingType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitNode(TreeNode) - Method in class org.infinispan.tools.doclet.config.XMLTreeOutputWalker
 
visitNode(TreeNode) - Method in interface org.infinispan.tools.schema.TreeWalker
 
Visitor - Interface in org.infinispan.commands
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in interface org.infinispan.commands.Visitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitQueryConfigurationBean(Configuration.QueryConfigurationBean) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitRecoveryType(Configuration.RecoveryType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitRecoveryType(Configuration.RecoveryType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitRecoveryType(Configuration.RecoveryType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitRecoveryType(Configuration.RecoveryType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitRemoteTransaction(RemoteTransaction) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
visitRemoteTransaction(RemoteTransaction) - Method in class org.infinispan.commands.tx.RollbackCommand
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DistributionInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.StateTransferLockInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitSerializationType(GlobalConfiguration.SerializationType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitSerializationType(GlobalConfiguration.SerializationType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitSerializationType(GlobalConfiguration.SerializationType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitShutdownType(GlobalConfiguration.ShutdownType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitShutdownType(GlobalConfiguration.ShutdownType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitShutdownType(GlobalConfiguration.ShutdownType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitSingletonStoreConfig(SingletonStoreConfig) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitSingletonStoreConfig(SingletonStoreConfig) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in interface org.infinispan.commands.Visitor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitStateRetrievalType(Configuration.StateRetrievalType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitStoreAsBinaryType(Configuration.StoreAsBinary) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitStoreAsBinaryType(Configuration.StoreAsBinary) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitStoreAsBinaryType(Configuration.StoreAsBinary) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitStoreAsBinaryType(Configuration.StoreAsBinary) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitSyncType(Configuration.SyncType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitSyncType(Configuration.SyncType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitSyncType(Configuration.SyncType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitSyncType(Configuration.SyncType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitTransactionType(Configuration.TransactionType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitTransactionType(Configuration.TransactionType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitTransportType(GlobalConfiguration.TransportType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitTransportType(GlobalConfiguration.TransportType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitTransportType(GlobalConfiguration.TransportType) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitTransportType(GlobalConfiguration.TransportType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in interface org.infinispan.commands.Visitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitUnsafeType(Configuration.UnsafeType) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in interface org.infinispan.commands.Visitor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
visitVersioningConfigurationBean(Configuration.VersioningConfigurationBean) - Method in class org.infinispan.config.AbstractConfigurationBeanVisitor
 
visitVersioningConfigurationBean(Configuration.VersioningConfigurationBean) - Method in interface org.infinispan.config.ConfigurationBeanVisitor
 
visitVersioningConfigurationBean(Configuration.VersioningConfigurationBean) - Method in class org.infinispan.config.ConfigurationValidatingVisitor
Deprecated.  
visitVersioningConfigurationBean(Configuration.VersioningConfigurationBean) - Method in class org.infinispan.config.DelegatingConfigurationVisitor
 
visitVersioningConfigurationBean(Configuration.VersioningConfigurationBean) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 

W

waitForCacheToStart(String) - Method in interface org.infinispan.util.logging.Log
 
waitForChannelToConnect() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
waitForJoinToComplete() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
waitForJoinToComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
waitForJoinToStart() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
waitForJoinToStart() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
waitForLockRelease(Object, long) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
waitForLockRelease(Object, long) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
waitForState() - Method in class org.infinispan.remoting.transport.jgroups.StateTransferMonitor
 
waitForStateTransferToComplete() - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
waitForStateTransferToComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
waitForStateTransferToEnd(InvocationContext, VisitableCommand, int) - Method in interface org.infinispan.statetransfer.StateTransferLock
Release the state lock temporarily in order to allow a pending state transfer to start.
waitForStateTransferToEnd(InvocationContext, VisitableCommand, int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
waitForStateTransferToStart(int) - Method in class org.infinispan.statetransfer.BaseStateTransferManagerImpl
 
wakeUp() - Method in class org.infinispan.cacheviews.CacheViewsManagerImpl.ViewTriggerThread
 
wakeUpInterval - Variable in class org.infinispan.config.Configuration.EvictionType
Deprecated. 
wakeUpInterval - Variable in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
wakeUpInterval(Long) - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.  
wakeUpInterval(Long) - Method in interface org.infinispan.config.FluentConfiguration.ExpirationConfig
Deprecated. Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores.
wakeUpInterval() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores.
wakeUpInterval(long) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores.
warnStrictPeerToPeerWithInjectedChannel() - Method in interface org.infinispan.util.logging.Log
 
WebSocketServer - Class in org.infinispan.server.websocket
An HTTP server which serves Web Socket requests on an Infinispan cacheManager.
WebSocketServer() - Constructor for class org.infinispan.server.websocket.WebSocketServer
 
WebSocketServerHandler - Class in org.infinispan.server.websocket
Web Socket Server Handler (Netty).
WebSocketServerHandler(CacheContainer, Map<String, OpHandler>, Map<String, Cache>) - Constructor for class org.infinispan.server.websocket.WebSocketServerHandler
 
wildcard(XSWildcard) - Method in class org.infinispan.tools.schema.XSOMSchemaTreeWalker
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryActivatedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryCreatedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryEvictedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryInvalidatedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryLoadedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryModifiedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryPassivatedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryRemovedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.CacheEntryVisitedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.TransactionCompletedAdapter
 
WILDCARD_TYPE - Static variable in class org.infinispan.cdi.event.cache.TransactionRegisteredAdapter
 
willUnmarshall(Object) - Method in class org.infinispan.config.AbstractConfigurationBean
 
willUnmarshall(Object) - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.  
willUnmarshall(Object) - Method in class org.infinispan.config.Configuration.ClusteringType
Deprecated.  
willUnmarshall(Object) - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.  
willUnmarshall(Object) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.  
willUnmarshall(Object) - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated.  
willUnmarshall(Object) - Method in interface org.infinispan.config.JAXBUnmarshallable
Indicates that this element is about to be unmarshalled from the XML source that was processed.
wireDependencies(Object) - Method in class org.infinispan.factories.AbstractComponentRegistry
Wires an object instance with dependencies annotated with the Inject annotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in the ComponentRegistry.
with(ClassLoader) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
with(ClassLoader) - Method in interface org.infinispan.AdvancedCache
Using this operation, users can call any AdvancedCache operation with a given ClassLoader.
with(ClassLoader) - Method in class org.infinispan.CacheImpl
 
with(ClassLoader) - Method in class org.infinispan.DecoratedCache
 
withAnnotationDeclared(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ClassFinder
 
withAnnotationPresent(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ClassFinder
 
withAnnotationPresent(Class<? extends Annotation>) - Static method in class org.infinispan.util.ClassFinder
 
withFlags(Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
withFlags(Flag...) - Method in interface org.infinispan.AdvancedCache
A method that adds flags to any API call.
withFlags(Flag...) - Method in class org.infinispan.CacheImpl
 
withFlags(Flag...) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
withFlags(Flag...) - Method in interface org.infinispan.client.hotrod.RemoteCache
Applies one or more Flags to the scope of a single invocation.
withFlags(Flag...) - Method in class org.infinispan.DecoratedCache
 
withGroupers(List<Grouper<?>>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Set the groupers to use
WithinThreadExecutor - Class in org.infinispan.util.concurrent
An executor that works within the current thread.
WithinThreadExecutor() - Constructor for class org.infinispan.util.concurrent.WithinThreadExecutor
 
withProperties(Properties) - Method in class org.infinispan.config.Configuration.DataContainerType
Deprecated.  
withProperties(Properties) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
Deprecated.  
withProperties(Properties) - Method in interface org.infinispan.config.FluentConfiguration.DataContainerConfig
Deprecated.  
withProperties(Properties) - Method in interface org.infinispan.config.FluentConfiguration.IndexingConfig
Deprecated. The Query engine relies on properties for configuration.
withProperties(Properties) - Method in interface org.infinispan.config.FluentGlobalConfiguration.ExecutorFactoryConfig
Deprecated. Set key/value properties to this executor factory configuration
withProperties(Properties) - Method in interface org.infinispan.config.FluentGlobalConfiguration.GlobalJmxStatisticsConfig
Deprecated. Sets properties which are then passed to the MBean Server Lookup implementation specified.
withProperties(Properties) - Method in interface org.infinispan.config.FluentGlobalConfiguration.TransportConfig
Deprecated. Sets transport properties
withProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration.ExecutorFactoryType
Deprecated.  
withProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration.FactoryClassWithPropertiesType
Deprecated.  
withProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.  
withProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration.ScheduledExecutorFactoryType
Deprecated.  
withProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.  
withProperties(Properties) - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
Properties passed to the cache store or loader
withProperties(Properties) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Set key/value properties to this DataContainer configuration
withProperties(Properties) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
withProperties(Properties) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
The Query engine relies on properties for configuration.
withProperties(Properties) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
These properties are passed directly to the cache loader.
withProperties(Properties) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
Set key/value properties to this executor factory configuration
withProperties(Properties) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Sets properties which are then passed to the MBean Server Lookup implementation specified.
withProperties(Properties) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
Set key/value properties to this executor factory configuration
withProperties(Properties) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Sets transport properties
WordCountCollator - Class in org.infinispan.demo.mapreduce
Collates reduced results by grouping them into the top K most frequent words.
WordCountCollator(int) - Constructor for class org.infinispan.demo.mapreduce.WordCountCollator
 
WordCountDemo - Class in org.infinispan.demo.mapreduce
Infinispan MapReduceTask demo
WordCountDemo(String[]) - Constructor for class org.infinispan.demo.mapreduce.WordCountDemo
 
WordCountMapper - Class in org.infinispan.demo.mapreduce
 
WordCountMapper() - Constructor for class org.infinispan.demo.mapreduce.WordCountMapper
 
WordCountReducer - Class in org.infinispan.demo.mapreduce
 
WordCountReducer() - Constructor for class org.infinispan.demo.mapreduce.WordCountReducer
 
wouldLose(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
wrapEntryForClear(InvocationContext, Object) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping individual keys when clearing the cache.
wrapEntryForClear(InvocationContext, Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForDelta(InvocationContext, Object, Delta) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping Delta entry to be applied to DeltaAware object stored in cache.
wrapEntryForDelta(InvocationContext, Object, Delta) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForPut(InvocationContext, Object, InternalCacheEntry, boolean) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for addition to cache.
wrapEntryForPut(InvocationContext, Object, InternalCacheEntry, boolean) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForReading(InvocationContext, Object) - Method in interface org.infinispan.container.EntryFactory
Wraps an entry for reading.
wrapEntryForReading(InvocationContext, Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForRemove(InvocationContext, Object) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for removal.
wrapEntryForRemove(InvocationContext, Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForReplace(InvocationContext, Object) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for replacement.
wrapEntryForReplace(InvocationContext, Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapMap(Map<Object, Object>, Set<MarshalledValue>, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
wrappedEntry - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
writable - Variable in class org.infinispan.tools.doclet.jmx.MBeanAttribute
 
WritableGridFileChannel - Class in org.infinispan.io
 
write(byte[], int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
write(int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
write(byte[], int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.io.GridOutputStream
 
write(byte[]) - Method in class org.infinispan.io.GridOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.GridOutputStream
 
write(int) - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
 
write(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[]) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(ByteBuffer) - Method in class org.infinispan.io.WritableGridFileChannel
 
write(int) - Method in class org.infinispan.util.Base64.OutputStream
Writes the byte to the output stream after converting to/from Base64 notation.
write(byte[], int, int) - Method in class org.infinispan.util.Base64.OutputStream
Calls Base64.OutputStream.write(int) repeatedly until len bytes are written.
writeArray(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeArray(byte[]) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(short) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeByte(short) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(byte) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
writeBytes(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeBytes(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBytes(byte[], int, int) - Method in class org.infinispan.lucene.InfinispanIndexOutput
 
writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
WriteCommand - Interface in org.infinispan.commands.write
A command that modifies the cache in some way
writeCommandHeader(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeCommandParameters(ObjectOutput, ReplicableCommand) - Static method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeExternal(ObjectOutput) - Method in class org.infinispan.io.GridFile.Metadata
 
writeExternal(Object, ObjectOutput) - Method in class org.infinispan.marshall.jboss.JBossExternalizerAdapter
 
writeExternal(ObjectOutput) - Method in class org.infinispan.nearcache.cdi.Address
 
writeExternal(ObjectOutput) - Method in class org.infinispan.util.ImmutableListCopy
Format: - entry array size (int) - elements (Object)
writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeHeader(Transport, short) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
writeHeader(Transport, HeaderParams) - Method in interface org.infinispan.client.hotrod.impl.protocol.Codec
Writes a request header with the given parameters to the transport and returns an updated header parameters.
writeHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
writeHeader(Transport, HeaderParams, byte) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
writeHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec11
 
writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeLong(long) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeLong(long) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeManagedAttributeAlreadyPresent(String) - Method in interface org.infinispan.util.logging.Log
 
writeObject(ObjectOutput, AtomicHashMap) - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
writeObject(ObjectOutput, AtomicHashMapDelta) - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
writeObject(ObjectOutput, ClearOperation) - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
writeObject(ObjectOutput, PutOperation) - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
writeObject(ObjectOutput, RemoveOperation) - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
writeObject(ObjectOutput, CacheView) - Method in class org.infinispan.cacheviews.CacheView.Externalizer
 
writeObject(ObjectOutput, ImmortalCacheEntry) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, ImmortalCacheValue) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
writeObject(ObjectOutput, MortalCacheEntry) - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, MortalCacheValue) - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
writeObject(ObjectOutput, TransientCacheEntry) - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
writeObject(ObjectOutput, TransientCacheValue) - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
writeObject(ObjectOutput, TransientMortalCacheEntry) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, TransientMortalCacheValue) - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
writeObject(ObjectOutput, VersionedImmortalCacheEntry) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, VersionedImmortalCacheValue) - Method in class org.infinispan.container.entries.versioned.VersionedImmortalCacheValue.Externalizer
 
writeObject(ObjectOutput, VersionedMortalCacheEntry) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, VersionedMortalCacheValue) - Method in class org.infinispan.container.entries.versioned.VersionedMortalCacheValue.Externalizer
 
writeObject(ObjectOutput, VersionedTransientCacheEntry) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheEntry.Externalizer
 
writeObject(ObjectOutput, VersionedTransientCacheValue) - Method in class org.infinispan.container.entries.versioned.VersionedTransientCacheValue.Externalizer
 
writeObject(ObjectOutput, VersionedTransientMortalCacheEntry) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, VersionedTransientMortalCacheValue) - Method in class org.infinispan.container.entries.versioned.VersionedTransientMortalCacheValue.Externalizer
 
writeObject(ObjectOutput, Flag) - Method in class org.infinispan.context.Flag.Externalizer
 
writeObject(ObjectOutput, T) - Method in class org.infinispan.distribution.ch.AbstractWheelConsistentHash.Externalizer
 
writeObject(ObjectOutput, ExperimentalDefaultConsistentHash) - Method in class org.infinispan.distribution.ch.ExperimentalDefaultConsistentHash.Externalizer
 
writeObject(ObjectOutput, UnionConsistentHash) - Method in class org.infinispan.distribution.ch.UnionConsistentHash.Externalizer
 
writeObject(ObjectOutput, RemoteTransactionLogDetails) - Method in class org.infinispan.distribution.RemoteTransactionLogDetails.Externalizer
 
writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeObject(ObjectOutput, Bucket) - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
writeObject(ObjectOutput, ChunkCacheKey) - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
writeObject(ObjectOutput, FileCacheKey) - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
writeObject(ObjectOutput, FileListCacheKey) - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
writeObject(ObjectOutput, FileMetadata) - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
writeObject(ObjectOutput, FileReadLockKey) - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
writeObject(ObjectOutput, T) - Method in interface org.infinispan.marshall.Externalizer
Write the object reference to the stream.
writeObject(ObjectOutput, ArrayList) - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
writeObject(ObjectOutput, CacheRpcCommand) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
writeObject(ObjectOutput, LinkedList) - Method in class org.infinispan.marshall.exts.LinkedListExternalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
writeObject(ObjectOutput, T) - Method in class org.infinispan.marshall.exts.NoStateExternalizer
 
writeObject(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeObject(ObjectOutput, Set) - Method in class org.infinispan.marshall.exts.SetExternalizer
 
writeObject(ObjectOutput, List<?>) - Method in class org.infinispan.marshall.exts.SingletonListExternalizer
 
writeObject(ObjectOutput, MarshalledValue) - Method in class org.infinispan.marshall.MarshalledValue.Externalizer
 
writeObject(ObjectOutput, ExceptionResponse) - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
writeObject(ObjectOutput, SuccessfulResponse) - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
writeObject(ObjectOutput, UnsuccessfulResponse) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
writeObject(ObjectOutput, UnsureResponse) - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
writeObject(ObjectOutput, JGroupsAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
writeObject(ObjectOutput, JGroupsTopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
writeObject(ObjectOutput, LockInfo) - Method in class org.infinispan.statetransfer.LockInfo.Externalizer
 
writeObject(ObjectOutput, DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
writeObject(ObjectOutput, T) - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
 
writeObject(ObjectOutput, InDoubtTxInfoImpl) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
 
writeObject(ObjectOutput, RecoveryAwareDldGlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
writeObject(ObjectOutput, RecoveryAwareGlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
writeObject(ObjectOutput, SerializableXid) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
 
writeObject(ObjectOutput, Fqn) - Method in class org.infinispan.tree.Fqn.Externalizer
 
writeObject(ObjectOutput, NodeKey) - Method in class org.infinispan.tree.NodeKey.Externalizer
 
writeObject(ObjectOutput, ByteArrayKey) - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeSkewCheck - Variable in class org.infinispan.config.Configuration.LockingType
Deprecated.  
writeSkewCheck(Boolean) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.  
writeSkewCheck(Boolean) - Method in interface org.infinispan.config.FluentConfiguration.LockingConfig
Deprecated. This setting is only applicable in the case of REPEATABLE_READ.
writeSkewCheck() - Method in class org.infinispan.configuration.cache.LockingConfiguration
This setting is only applicable in the case of REPEATABLE_READ.
writeSkewCheck(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
This setting is only applicable in the case of REPEATABLE_READ.
WriteSkewException - Exception in org.infinispan.transaction
Thrown when a write skew is detected
WriteSkewException() - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewException(Throwable) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewException(String) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewException(String, Throwable) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewHelper - Class in org.infinispan.transaction
Encapsulates write skew logic in maintaining version maps, etc.
WriteSkewHelper() - Constructor for class org.infinispan.transaction.WriteSkewHelper
 
WriteSkewHelper.KeySpecificLogic - Interface in org.infinispan.transaction
 
writesToASingleKey() - Method in class org.infinispan.commands.tx.PrepareCommand
 
writeString(String) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeString(String) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeUnsignedInt(ObjectOutput, int) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedInt(OutputStream, int) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedInt(ByteBuffer, int) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedInt(byte[], int, int) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(ObjectOutput, long) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(OutputStream, long) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedLong(ByteBuffer, long) - Static method in class org.infinispan.io.UnsignedNumeric
 
writeUnsignedLong(byte[], int, long) - Static method in class org.infinispan.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUTF(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeVInt(int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeVInt(int) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeVLong(long) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeVLong(long) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 

X

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

_

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

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

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