Infinispan Core 5.2.11.Final-redhat-2
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

abortingJoin(Exception) - Method in interface org.infinispan.util.logging.Log
 
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() - Constructor for class org.infinispan.factories.AbstractComponentRegistry
 
AbstractComponentRegistry.Component - Class in org.infinispan.factories
A wrapper representing a component in the registry
AbstractComponentRegistry.Component() - Constructor for class org.infinispan.factories.AbstractComponentRegistry.Component
 
AbstractConfigurationBean - Class in org.infinispan.config
Base superclass of Cache configuration classes that expose some properties that can be changed after the cache is started.
AbstractConfigurationBean() - Constructor for class org.infinispan.config.AbstractConfigurationBean
 
AbstractConfigurationBeanVisitor - Class in org.infinispan.config
AbstractConfigurationBeanVisitor is a convenience super class for ConfigurationBeanVisitor classes.
AbstractConfigurationBeanVisitor() - Constructor for class org.infinispan.config.AbstractConfigurationBeanVisitor
 
AbstractCustomFailurePolicy<K,V> - Class in org.infinispan.xsite
Support class for CustomFailurePolicy.
AbstractCustomFailurePolicy() - Constructor for class org.infinispan.xsite.AbstractCustomFailurePolicy
 
AbstractCustomInterceptorsConfigurationChildBuilder - 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
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
 
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>, AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
 
AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K,V> - Interface in org.infinispan
 
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
 
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
 
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
 
AbstractGlobalModuleConfigurationBuilder<T> - Class in org.infinispan.configuration.global
 
AbstractGlobalModuleConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.AbstractGlobalModuleConfigurationBuilder
 
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
 
AbstractInvocationContextContainer - Class in org.infinispan.context
Base class for InvocationContextContainer implementations.
AbstractInvocationContextContainer() - Constructor for class org.infinispan.context.AbstractInvocationContextContainer
 
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
 
AbstractJmxRegistration - Class in org.infinispan.jmx
Parent class for top level JMX component registration.
AbstractJmxRegistration() - Constructor for class org.infinispan.jmx.AbstractJmxRegistration
 
AbstractListenerImpl - Class in org.infinispan.notifications
Functionality common to both CacheManagerNotifierImpl and CacheNotifierImpl
AbstractListenerImpl() - Constructor for class org.infinispan.notifications.AbstractListenerImpl
 
AbstractListenerImpl.ListenerInvocation - Class in org.infinispan.notifications
Class that encapsulates a valid invocation for a given registered listener - containing a reference to the method to be invoked as well as the target object.
AbstractListenerImpl.ListenerInvocation(Object, Method, boolean, ClassLoader) - Constructor for class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
AbstractLoaderConfiguration - Class in org.infinispan.configuration.cache
AbstractLoaderConfiguration.
AbstractLoaderConfiguration(TypedProperties) - Constructor for class org.infinispan.configuration.cache.AbstractLoaderConfiguration
 
AbstractLoaderConfigurationBuilder<T extends CacheLoaderConfiguration,S extends AbstractLoaderConfigurationBuilder<T,S>> - Class in org.infinispan.configuration.cache
 
AbstractLoaderConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
 
AbstractLoaderConfigurationChildBuilder<S> - Class in org.infinispan.configuration.cache
AbstractLoaderConfigurationChildBuilder delegates LoaderConfigurationChildBuilder methods to a specified CacheLoaderConfigurationBuilder
AbstractLoaderConfigurationChildBuilder(CacheLoaderConfigurationBuilder<? extends AbstractLoaderConfiguration, ? extends CacheLoaderConfigurationBuilder<?, ?>>) - Constructor for class org.infinispan.configuration.cache.AbstractLoaderConfigurationChildBuilder
 
AbstractLoadersConfigurationChildBuilder - Class in org.infinispan.configuration.cache
AbstractLoadersConfigurationChildBuilder.
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
 
AbstractLockSupportStoreConfiguration - Class in org.infinispan.configuration.cache
Lock supporting cache store configuration.
AbstractLockSupportStoreConfiguration(long, int, boolean, boolean, int, boolean, boolean, TypedProperties, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractLockSupportStoreConfiguration
 
AbstractLockSupportStoreConfigurationBuilder<T extends LockSupportStoreConfiguration,S extends AbstractLockSupportStoreConfigurationBuilder<T,S>> - Class in org.infinispan.configuration.cache
AbstractLockSupportCacheStoreConfigurationBuilder.
AbstractLockSupportStoreConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationBuilder
 
AbstractLockSupportStoreConfigurationChildBuilder<S> - Class in org.infinispan.configuration.cache
AbstractLockSupportStoreConfigurationChildBuilder delegates LockSupportStoreConfigurationChildBuilder methods to a specified LockSupportStoreConfigurationBuilder
AbstractLockSupportStoreConfigurationChildBuilder(AbstractLockSupportStoreConfigurationBuilder<? extends AbstractLockSupportStoreConfiguration, ? extends LockSupportStoreConfigurationBuilder<?, ?>>) - Constructor for class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationChildBuilder
 
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
 
AbstractModuleConfigurationBuilder - Class in org.infinispan.configuration.cache
AbstractModuleConfigurationBuilder.
AbstractModuleConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
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
 
AbstractParserContext - Class in org.infinispan.configuration.parsing
 
AbstractParserContext() - Constructor for class org.infinispan.configuration.parsing.AbstractParserContext
 
AbstractPerEntryLockContainer<L extends RefCountingLock> - 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
 
AbstractStoreConfiguration - Class in org.infinispan.configuration.cache
 
AbstractStoreConfiguration(boolean, boolean, int, boolean, boolean, TypedProperties, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
AbstractStoreConfigurationBuilder<T extends CacheStoreConfiguration,S extends AbstractStoreConfigurationBuilder<T,S>> - Class in org.infinispan.configuration.cache
 
AbstractStoreConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
AbstractStoreConfigurationChildBuilder<S> - Class in org.infinispan.configuration.cache
AbstractStoreConfigurationChildBuilder delegates StoreConfigurationChildBuilder methods to a specified CacheStoreConfigurationBuilder
AbstractStoreConfigurationChildBuilder(AbstractStoreConfigurationBuilder<? extends AbstractStoreConfiguration, ?>) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
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.remoting.transport
Common transport-related behaviour
AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
 
AbstractTransportConfigurationChildBuilder - Class in org.infinispan.configuration.cache
 
AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
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
 
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
 
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.remote.ClusteredGetCommand
 
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.
acquireExclusiveTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireExclusiveTopologyLock() - 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, long, boolean) - 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, boolean) - 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, long, boolean) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Same as LockManager.acquireLock(org.infinispan.context.InvocationContext, Object, long, boolean), but doesn't check whether the lock is already acquired by the caller.
acquireLockNoCheck(InvocationContext, Object, long, boolean) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
acquireSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
activate(Object) - Method in interface org.infinispan.eviction.ActivationManager
Remove key and associated value from cache store and update the activation counter.
activate(Object) - Method in class org.infinispan.eviction.ActivationManagerImpl
 
activated - Variable in class org.infinispan.config.Configuration.HashType
Deprecated.
 
activated - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.
 
ActivationInterceptor - Class in org.infinispan.interceptors
 
ActivationInterceptor() - Constructor for class org.infinispan.interceptors.ActivationInterceptor
 
ActivationManager - Interface in org.infinispan.eviction
Controls activation of cache entries that have been passivated.
ActivationManagerImpl - Class in org.infinispan.eviction
Concrete implementation of activation logic manager.
ActivationManagerImpl() - Constructor for class org.infinispan.eviction.ActivationManagerImpl
 
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() - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfiguration
 
adapt() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
adapt(Configuration) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(CacheLoaderConfiguration) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(Configuration) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(Configuration, ClassLoader) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(ClassLoader, ConfigurationBuilder, CacheLoaderConfig) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt(CacheStoreConfiguration, CacheStoreConfig) - Static method in class org.infinispan.configuration.cache.LegacyConfigurationAdaptor
 
adapt() - Method in interface org.infinispan.configuration.cache.LegacyLoaderAdapter
Deprecated.
 
adapt(GlobalConfiguration) - Static method in class org.infinispan.configuration.global.LegacyGlobalConfigurationAdaptor
 
adapt(GlobalConfiguration) - Static method in class org.infinispan.configuration.global.LegacyGlobalConfigurationAdaptor
 
adapt(Runnable) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns a null result upon ForkJoinTask.join().
adapt(Runnable, T) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns the given result upon ForkJoinTask.join().
adapt(Callable<? extends T>) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns a new ForkJoinTask that performs the call method of the given Callable as its action, and returns its result upon ForkJoinTask.join(), translating any checked exceptions encountered into RuntimeException.
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(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(K) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
Adds the specified key to this set view by mapping the key to the default mapped value in the backing map, if defined.
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.
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.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(Collection<? extends K>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
Adds all of the elements in the specified collection to this set, as if by calling ConcurrentHashMapV8.KeySetView.add(K) on each one.
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.transaction.AbstractCacheTransaction
 
addBackup() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
addBackupLockForKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory
 
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
Deprecated.
addCacheLoader(CacheLoader, CacheLoaderConfiguration) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
addCacheLoaderConfig(CacheLoaderConfig) - Method in class org.infinispan.config.CacheLoaderManagerConfig
addClusterCacheLoader() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cluster cache loader
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
 
addFailure(String, Throwable) - Method in exception org.infinispan.xsite.BackupFailureException
 
addFileCacheStore() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a file cache store
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.
addInterface(NetworkInterface) - Method in class org.infinispan.configuration.as.ParserContextAS7
 
addInUseBackupSite(String) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
Defines the site names, from the list of sites names defined within 'backups' element, to which this cache backups its data.
addListener(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
addListener(Object) - Method in class org.infinispan.CacheImpl
 
addListener(Object) - Method in class org.infinispan.DecoratedCache
 
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, ClassLoader) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
addListener(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
 
addListener(Object) - Method in interface org.infinispan.notifications.Listenable
Adds a listener to the component.
addLoader() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cache loader to the configuration.
addLoader(Class<T>) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cache loader which uses the specified builder class to build its configuration
addLoader(CacheLoaderConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cache loader which uses the specified builder instance to build its configuration
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.SingleKeyNonTxInvocationContext
 
addMember(Address) - Method in class org.infinispan.topology.ClusterCacheStatus
 
addModification(WriteCommand) - Method in class org.infinispan.transaction.LocalTransaction
 
addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
addOperation(Operation<?, ?>) - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
addOutboundSocketBinding(OutboundSocketBinding) - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
addOwner(int, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addOwners(int, Collection<Address>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
addParsingCompleteListener(ParserContextListener) - Method in class org.infinispan.configuration.parsing.AbstractParserContext
 
addParsingCompleteListener(ParserContextListener) - Method in interface org.infinispan.configuration.parsing.ParserContext
 
addPrimaryOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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.AbstractLoaderConfigurationBuilder
Defines a single property.
addProperty(String, String) - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationChildBuilder
 
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.LegacyLoaderConfigurationBuilder
Defines a single property.
addProperty(String, String) - Method in interface org.infinispan.configuration.cache.LoaderConfigurationChildBuilder
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() - Method in class org.infinispan.configuration.as.NetworkInterface
 
address() - Method in class org.infinispan.configuration.as.SocketBinding
 
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
 
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
addSocketBinding(SocketBinding) - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
addSocketBindingGroup(SocketBindingGroup) - Method in class org.infinispan.configuration.as.ParserContextAS7
 
addSourceMigrator(SourceMigrator) - Method in class org.infinispan.upgrade.RollingUpgradeManager
Registers a migrator for a specific data format or endpoint.
addStatus(Set<Integer>) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addStore() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cache store to the configuration.
addStore(Class<T>) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cache store which uses the specified builder class to build its configuration
addStore(CacheStoreConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Adds a cache store which uses the specified builder instance to build its configuration
addToPendingCount(int) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Adds (atomically) the given value to the pending count.
addUpdatedKey(Object) - Method in interface org.infinispan.statetransfer.StateConsumer
Receive notification of updated keys right before they are committed in DataContainer.
addUpdatedKey(Object) - Method in class org.infinispan.statetransfer.StateConsumerImpl
Receive notification of updated keys right before they are committed in DataContainer.
AdvancedCache<K,V> - Interface in org.infinispan
An advanced interface that exposes additional methods not available on Cache.
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
Holds all the locked keys that were acquired by the transaction allover the cluster.
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
 
afterFailures() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
afterFailures(int) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
The number of failed request operations after which this site should be taken offline.
AggregateBackupResponse - Class in org.infinispan.remoting.transport
 
AggregateBackupResponse(BackupResponse, BackupResponse) - Constructor for class org.infinispan.remoting.transport.AggregateBackupResponse
 
aggregateReducedResult(Map<KOut, List<VOut>>, Map<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
AggregatingNotifyingFutureImpl<T> - Class in org.infinispan.util.concurrent
For use with > 1 underlying network future
AggregatingNotifyingFutureImpl(T, 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
 
allBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns the list of all sites where this cache might back up its data.
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
 
amend(TakeOfflineConfiguration) - Method in class org.infinispan.xsite.OfflineStatus
Configures the site to use the supplied configuration for determining when to take a site offline.
amend(Integer, Long) - Method in class org.infinispan.xsite.OfflineStatus
 
amendTakeOffline(String, int, long) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
appendDelta(Delta) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
appendInterceptor(CommandInterceptor, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
Appends at the end.
apply(CacheMode) - Method in enum org.infinispan.configuration.as.Mode
 
apply(A) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.Action
 
apply(A, B) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.BiAction
 
apply(A, B) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.BiFun
 
apply(double, double) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.DoubleByDoubleToDouble
 
apply(A) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.Fun
 
apply(int, int) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.IntByIntToInt
 
apply(long, long) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.LongByLongToLong
 
apply(A, B) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ObjectByObjectToDouble
 
apply(A, B) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ObjectByObjectToInt
 
apply(A, B) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ObjectByObjectToLong
 
apply(A) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ObjectToDouble
 
apply(A) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ObjectToInt
 
apply(A) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ObjectToLong
 
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
 
applyModifications(List<? extends Modification>) - Method in class org.infinispan.loaders.AbstractCacheStore
 
applyModificationsSync(List<Modification>) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
applyOverrides(Configuration) - Method in class org.infinispan.config.Configuration
Deprecated.
 
applyState(Address, int, Collection<StateChunk>) - Method in interface org.infinispan.statetransfer.StateConsumer
 
applyState(Address, int, Collection<StateChunk>) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
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
 
assertKeyNotNull(Object) - Static method in class org.infinispan.util.AbstractMap
 
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.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.AbstractStoreConfiguration
Configuration for the async cache loader.
async - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Configuration for the async cache loader.
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
async() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
Configuration for the async cache loader.
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.StoreConfigurationChildBuilder
Configuration for the async cache store.
async - Variable in class org.infinispan.loaders.AbstractCacheStoreConfig
 
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_REPLICATION_QUEUE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_TRANSPORT_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
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.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
 
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.
asyncMarshalling(boolean) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
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 buffers changes and writes them asynchronously to the underlying CacheStore.
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
 
AsyncStoreConfiguration - Class in org.infinispan.configuration.cache
Configuration for the async cache store.
AsyncStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
Configuration for the async cache store.
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<V>) - Method in class org.infinispan.util.concurrent.AbstractInProcessNotifyingFuture
 
attachListener(FutureListener<T>) - Method in class org.infinispan.util.concurrent.BaseNotifyingFuture
 
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'.
Attribute - Enum in org.infinispan.configuration.as
Enumerates the attributes used in Infinispan
Attribute - Enum in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
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
 
awaitCompletion() - Method in class org.infinispan.statetransfer.InboundTransferTask
Wait until all segments are received, cancelled, or the task is terminated abruptly by terminate().
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.
awaitInitialTransfer() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
If true, this will cause the first call to method CacheManager.getCache() on the joiner node to block and wait until the joining is complete and the cache has finished receiving state from neighboring caches (if fetchInMemoryState is enabled).
awaitInitialTransfer(boolean) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
If true, this will cause the first call to method CacheManager.getCache() on the joiner node to block and wait until the joining is complete and the cache has finished receiving state from neighboring caches (if fetchInMemoryState is enabled).
awaitQuiescence(long, TimeUnit) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
If called by a ForkJoinTask operating in this pool, equivalent in effect to ForkJoinTask.helpQuiesce().
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.jdk8backported.ForkJoinPool
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 

B

backup() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
backupCommit(CommitCommand) - Method in interface org.infinispan.xsite.BackupSender
 
backupCommit(CommitCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
BackupConfiguration - Class in org.infinispan.configuration.cache
 
BackupConfiguration(String, BackupConfiguration.BackupStrategy, long, BackupFailurePolicy, String, boolean, TakeOfflineConfiguration, boolean) - Constructor for class org.infinispan.configuration.cache.BackupConfiguration
 
BackupConfiguration.BackupStrategy - Enum in org.infinispan.configuration.cache
 
BackupConfigurationBuilder - Class in org.infinispan.configuration.cache
 
BackupConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
BackupFailureException - Exception in org.infinispan.xsite
Exception to be used to signal failures to backup to remote sites.
BackupFailureException(String) - Constructor for exception org.infinispan.xsite.BackupFailureException
 
BackupFailureException() - Constructor for exception org.infinispan.xsite.BackupFailureException
 
backupFailurePolicy() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
backupFailurePolicy(BackupFailurePolicy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Configures how the system behaves when the backup call fails.
backupFailurePolicy() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
BackupFailurePolicy - Enum in org.infinispan.configuration.cache
Defines the possible behaviour in case of failure during x-site.
backupFor() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
backupFor() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
BackupForBuilder - Class in org.infinispan.configuration.cache
 
BackupForBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupForBuilder
 
BackupForConfiguration - Class in org.infinispan.configuration.cache
Defines the remote caches for which this cache acts as a backup.
BackupForConfiguration(String, String) - Constructor for class org.infinispan.configuration.cache.BackupForConfiguration
 
backupKeyLocks - Variable in class org.infinispan.transaction.AbstractCacheTransaction
Holds all the locks for which the local node is a secondary data owner.
backupPrepare(PrepareCommand) - Method in interface org.infinispan.xsite.BackupSender
Prepares a transaction on the remote site.
backupPrepare(PrepareCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
BackupReceiver - Interface in org.infinispan.xsite
Component present on a backup site that manages the backup information and logic.
BackupReceiverImpl - Class in org.infinispan.xsite
 
BackupReceiverImpl(Cache) - Constructor for class org.infinispan.xsite.BackupReceiverImpl
 
BackupReceiverImpl.BackupCacheUpdater - Class in org.infinispan.xsite
 
BackupReceiverRepository - Interface in org.infinispan.xsite
Global component that holds all the BackupReceivers within this CacheManager.
BackupReceiverRepositoryImpl - Class in org.infinispan.xsite
 
BackupReceiverRepositoryImpl() - Constructor for class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
backupRemotely(Collection<XSiteBackup>, ReplicableCommand) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
backupRemotely(Collection<XSiteBackup>, ReplicableCommand) - Method in interface org.infinispan.remoting.transport.Transport
 
BackupResponse - Interface in org.infinispan.remoting.transport
Represents a response from a backup replication call.
backupRollback(RollbackCommand) - Method in interface org.infinispan.xsite.BackupSender
 
backupRollback(RollbackCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
backups() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
backupSender - Variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
BackupSender - Interface in org.infinispan.xsite
Component responsible with sending backup data to remote sites.
BackupSender.BringSiteOnlineResponse - Enum in org.infinispan.xsite
 
BackupSender.TakeSiteOfflineResponse - Enum in org.infinispan.xsite
 
BackupSenderImpl - Class in org.infinispan.xsite
 
BackupSenderImpl(String) - Constructor for class org.infinispan.xsite.BackupSenderImpl
 
BackupSenderImpl.CustomBackupPolicyInvoker - Class in org.infinispan.xsite
 
BackupSenderImpl.CustomBackupPolicyInvoker(String, CustomFailurePolicy, Transaction) - Constructor for class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
backupWrite(WriteCommand) - Method in interface org.infinispan.xsite.BackupSender
 
backupWrite(WriteCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
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.
BaseBackupInterceptor - Class in org.infinispan.interceptors.xsite
 
BaseBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
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
 
BaseDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Base class for distribution of entries across a cluster.
BaseDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
BaseNotifyingFuture<T> - Class in org.infinispan.util.concurrent
 
BaseNotifyingFuture() - Constructor for class org.infinispan.util.concurrent.BaseNotifyingFuture
 
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
 
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
 
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
 
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.
block() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
block() - Method in interface org.infinispan.util.concurrent.jdk8backported.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
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
 
bringOnline() - Method in class org.infinispan.xsite.OfflineStatus
 
bringSiteOnline(String) - Method in interface org.infinispan.xsite.BackupSender
Brings a site with the given name back online.
bringSiteOnline(String) - Method in class org.infinispan.xsite.BackupSenderImpl
 
bringSiteOnline(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
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, 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
 
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 interface org.infinispan.distexec.DistributedTaskBuilder
Completes creation of DistributedTask with the currently provided attributes of this DistributedTaskBuilder
build(Hash) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
Get back up to the CacheStoreConfig level.
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
 
buildCancelCommandCommand(UUID) - Method in interface org.infinispan.commands.CommandsFactory
Builds CancelCommandCommand used to cancel other commands executing on Infinispan cluster
buildCancelCommandCommand(UUID) - 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
 
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
 
buildCreateCacheCommand(String, String) - Method in interface org.infinispan.commands.CommandsFactory
Same as #buildCreateCacheCommand(String, String, false).
buildCreateCacheCommand(String, String, boolean, int) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CreateCacheCommand used to create/start cache around Infinispan cluster
buildCreateCacheCommand(String, String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCreateCacheCommand(String, String, boolean, int) - 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
 
Builder<T> - Interface in org.infinispan.configuration
Builder.
builderFor(B) - Static method in class org.infinispan.configuration.ConfigurationUtils
 
buildEvictCommand(Object, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an EvictCommand
buildEvictCommand(Object, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetCacheEntryCommand(Object, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
buildGetCacheEntryCommand(Object, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetInDoubtTransactionsCommand() - Method in interface org.infinispan.commands.CommandsFactory
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(Set<Flag>, Object...) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateCommand
buildInvalidateCommand(Set<Flag>, Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(boolean, Set<Flag>, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateFromL1Command
buildInvalidateFromL1Command(Address, boolean, Set<Flag>, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateFromL1Command(boolean, Set<Flag>, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(Address, boolean, Set<Flag>, 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
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
 
buildMapCombineCommand(String, Mapper<KIn, VIn, KOut, VOut>, Reducer<KOut, VOut>, Collection<KIn>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a MapCombineCommand used for migration and map phase execution of MapReduce tasks.
buildMapCombineCommand(String, Mapper<KIn, VIn, KOut, VOut>, Reducer<KOut, VOut>, Collection<KIn>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PrepareCommand
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutKeyValueCommand(Object, Object, long, long, 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
 
buildReduceCommand(String, String, Reducer<KOut, VOut>, Collection<KOut>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReduceCommand used for migration and reduce phase execution of MapReduce tasks.
buildReduceCommand(String, String, Reducer<KOut, VOut>, Collection<KOut>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRegistrar(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
buildRegistrar(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
buildRegistrar(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
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
 
buildStateRequestCommand(StateRequestCommand.Type, Address, int, Set<Integer>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a StateRequestCommand used for requesting transactions and locks and for starting or canceling transfer of cache entries.
buildStateRequestCommand(StateRequestCommand.Type, Address, int, Set<Integer>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateResponseCommand(Address, int, Collection<StateChunk>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a StateResponseCommand used for pushing cache entries to another node in response to a StateRequestCommand.
buildStateResponseCommand(Address, int, Collection<StateChunk>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(Xid, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
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
 
BuiltBy - Annotation Type in org.infinispan.configuration
BuiltBy.
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.distexec.mapreduce.MapReduceTask
 
cache - Variable in class org.infinispan.interceptors.base.BaseCustomInterceptor
 
cache - Variable in class org.infinispan.loaders.AbstractCacheLoader
 
cache - Variable in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
CACHE_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheJmxRegistration
 
CACHE_JOIN_INFO - Static variable in interface org.infinispan.marshall.Ids
 
CACHE_MANAGER_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheManagerJmxRegistration
 
CACHE_MARSHALLER - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_NOT_FOUND_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
CACHE_RPC_COMMAND - Static variable in interface org.infinispan.marshall.Ids
 
CACHE_STOPPED_TOPOLOGY_ID - Static variable in class org.infinispan.transaction.TransactionTable
 
CACHE_TOPOLOGY - Static variable in interface org.infinispan.marshall.Ids
 
cacheBackupsDataToSameSite(String) - Method in interface org.infinispan.util.logging.Log
 
cacheComponents() - Method in class org.infinispan.factories.ComponentRegistry
Invoked last after all services are wired
cacheConfiguration - Variable in class org.infinispan.interceptors.base.CommandInterceptor
 
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 - Interface in org.infinispan.manager
 
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.
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.
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
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.
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.
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.
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.
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.
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.
CacheEntryVisitedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryVisited.
CacheException - Exception in org.infinispan
Thrown when operations on Cache fail unexpectedly.
CacheException() - Constructor for exception org.infinispan.CacheException
 
CacheException(Throwable) - Constructor for exception org.infinispan.CacheException
 
CacheException(String) - Constructor for exception org.infinispan.CacheException
 
CacheException(String, Throwable) - Constructor for exception org.infinispan.CacheException
 
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
 
CacheJmxRegistration - Class in org.infinispan.jmx
If Configuration.jmxStatistics() is enabled, then class will register all the MBeans from cache local's ConfigurationRegistry to the MBean server.
CacheJmxRegistration() - Constructor for class org.infinispan.jmx.CacheJmxRegistration
 
CacheJoinInfo - Class in org.infinispan.topology
This class contains the information that a cache needs to supply to the coordinator when starting up.
CacheJoinInfo(ConsistentHashFactory, Hash, int, int, long) - Constructor for class org.infinispan.topology.CacheJoinInfo
 
CacheJoinInfo.Externalizer - Class in org.infinispan.topology
 
CacheJoinInfo.Externalizer() - Constructor for class org.infinispan.topology.CacheJoinInfo.Externalizer
 
cacheLoader() - Method in class org.infinispan.configuration.cache.LegacyLoaderConfiguration
 
cacheLoader(CacheLoader) - Method in class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
cacheLoader(CacheLoader) - Method in class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
Deprecated.
cacheLoader(CacheLoader) - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
Deprecated.
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
 
CacheLoaderConfiguration - Interface in org.infinispan.configuration.cache
LoaderConfiguration
CacheLoaderConfigurationBuilder<T extends CacheLoaderConfiguration,S extends CacheLoaderConfigurationBuilder<T,S>> - Interface in org.infinispan.configuration.cache
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
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
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
 
CacheManager - Interface in org.infinispan.manager
Deprecated.
cacheManager - Variable in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
cacheManagerAlreadyRegistered(String) - Method in interface org.infinispan.util.logging.Log
 
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 class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
Deprecated.
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
 
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 - Variable in class org.infinispan.commands.remote.BaseRpcCommand
 
cacheName - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
CacheNotFoundResponse - Class in org.infinispan.remoting.responses
A response that signals the named cache is not running on the target node.
CacheNotFoundResponse() - Constructor for class org.infinispan.remoting.responses.CacheNotFoundResponse
 
CacheNotFoundResponse.Externalizer - Class in org.infinispan.remoting.responses
 
CacheNotFoundResponse.Externalizer() - Constructor for class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
 
CacheNotifier - Interface in org.infinispan.notifications.cachelistener
Public interface with all allowed notifications.
CacheNotifierImpl - Class in org.infinispan.notifications.cachelistener
Helper class that handles all notifications to registered listeners.
CacheNotifierImpl() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
cacheNotStarted() - Method in interface org.infinispan.util.logging.Log
 
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
 
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.
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 class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
Deprecated.
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(CacheStoppedEvent) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
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
 
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.
cacheStopTimeout(long, TimeUnit) - 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() - Method in class org.infinispan.configuration.cache.LegacyStoreConfiguration
 
cacheStore(CacheStore) - Method in class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
cacheStore() - Method in class org.infinispan.configuration.cache.LoaderConfiguration
 
cacheStore(CacheStore) - 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.
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.
CacheStoreConfiguration - Interface in org.infinispan.configuration.cache
 
CacheStoreConfigurationBuilder<T extends CacheStoreConfiguration,S extends CacheStoreConfigurationBuilder<T,S>> - Interface in org.infinispan.configuration.cache
StoreConfigurationBuilder is the interface which should be implemented by all cache store builders
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
 
CacheTopology - Class in org.infinispan.topology
The status of a cache from a distribution/state transfer point of view.
CacheTopology(int, ConsistentHash, ConsistentHash) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology.Externalizer - Class in org.infinispan.topology
 
CacheTopology.Externalizer() - Constructor for class org.infinispan.topology.CacheTopology.Externalizer
 
CacheTopologyControlCommand - Class in org.infinispan.topology
A control command for all cache membership/rebalance operations.
CacheTopologyControlCommand() - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
 
CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
 
CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, CacheJoinInfo, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
 
CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, int, Throwable, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
 
CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, CacheTopology, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
 
CacheTopologyControlCommand.Type - Enum in org.infinispan.topology
 
CacheTopologyHandler - Interface in org.infinispan.topology
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
 
cacheViewRollbackIdMismatch(int, int) - Method in interface org.infinispan.util.logging.Log
 
calculateRank(Address, List<Address>, long) - Method in class org.infinispan.util.ClusterIdGenerator
 
calculateRank(ViewChangedEvent) - Method in class org.infinispan.util.ClusterIdGenerator.RankCalculator
 
callable(Callable<T>) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
Provide relevant Callable for the DistributedTask
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(UUID) - Method in interface org.infinispan.commands.CancellationService
Cancels (invokes Thread#interrupt) a thread given a thread id
cancel(UUID) - Method in class org.infinispan.commands.CancellationServiceImpl
 
cancel() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
cancel() - Method in class org.infinispan.statetransfer.OutboundTransferTask
Cancel the whole task.
cancel(boolean) - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Attempts to cancel execution of this task.
cancel(boolean) - Method in class org.infinispan.util.concurrent.NoOpFuture
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.NotifyingFutureAdaptor
 
cancel(boolean) - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
CancelCommand - Class in org.infinispan.commands
Command to cancel commands executing in remote VM
CancelCommand(String) - Constructor for class org.infinispan.commands.CancelCommand
 
CancelCommand(String, UUID) - Constructor for class org.infinispan.commands.CancelCommand
 
CancellableCommand - Interface in org.infinispan.commands
CancellableCommand is a command whose execution in remote VM can be canceled (if needed)
cancellableTasks - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
CancellationService - Interface in org.infinispan.commands
CancellationService manages association of Thread executing CancellableCommand in a remote VM and if needed cancels command execution
cancellationService - Variable in class org.infinispan.distexec.DefaultExecutorService
 
cancellationService - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
CancellationServiceImpl - Class in org.infinispan.commands
CancellationServiceImpl is a default implementation of CancellationService
CancellationServiceImpl() - Constructor for class org.infinispan.commands.CancellationServiceImpl
 
cancelOutboundTransfer(Address, int, Set<Integer>) - Method in interface org.infinispan.statetransfer.StateProvider
Cancel sending of cache entries that belong to the given set of segments.
cancelOutboundTransfer(Address, int, Set<Integer>) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
cancelSegments(Set<Integer>) - Method in class org.infinispan.statetransfer.InboundTransferTask
Cancels a subset of the segments.
cancelSegments(Set<Integer>) - Method in class org.infinispan.statetransfer.OutboundTransferTask
Cancel some of the segments.
canExecute() - Method in class org.infinispan.io.GridFile
 
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
 
cannotRespondToCommit(GlobalTransaction, String) - Method in interface org.infinispan.util.logging.Log
 
cannotRespondToRollback(GlobalTransaction, String) - Method in interface org.infinispan.util.logging.Log
 
cannotSelectRandomMembers(int, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
canRead() - Method in class org.infinispan.io.GridFile
 
canWrite() - Method in class org.infinispan.io.GridFile
 
cause() - Method in interface org.infinispan.distexec.FailoverContext
Returns the Throwable which was the cause of the task failure.
cdl - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
cdl - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
cf - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
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
 
checkForOutdatedTopology(WriteCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
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
 
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
 
classLoader - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
ClassLoaderAwareListenable - Interface in org.infinispan.notifications
Interface that enhances Listenable with the possibility of specifying the ClassLoader which should be set as the context class loader for the invoked listener method
className - Variable in class org.infinispan.config.CustomInterceptorConfig
 
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
 
cleanupCompletedTransactions() - Method in class org.infinispan.transaction.TransactionTable
 
cleanupStaleTransactions(CacheTopology) - Method in class org.infinispan.transaction.TransactionTable
 
cleanupStaleTransactions(CacheTopology) - 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.
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
cleanupTaskFrequency(long, TimeUnit) - 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() - 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 interface org.infinispan.loaders.CacheStore
Clears all entries in the store
clear() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
clear() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
clear() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
clear() - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
clear() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
clear() - Method in class org.infinispan.loaders.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.marshall.MarshallableTypeHints
Clear the cached marshallable type hints.
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
 
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.DecoratedCache
 
clearCacheLoaders() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
Removes any configured cache loaders and stores from this builder
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
 
clearEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
clearGroupers() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Clear the groupers
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.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.file.FileCacheStore
 
clearLockSafe() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
clearLookedUpEntries() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
clearLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
clearModules() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
clearModules() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
ClearOperation<K,V> - Class in org.infinispan.atomic
An atomic clear operation.
clearOperation() - Method in class org.infinispan.CacheImpl
 
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.
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.SingleKeyNonTxInvocationContext
 
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.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.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
 
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
 
ClusterCacheLoaderConfiguration - Class in org.infinispan.configuration.cache
ClusterCacheLoaderConfiguration.
ClusterCacheLoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
 
ClusterCacheLoaderConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
ClusterCacheStatus - Class in org.infinispan.topology
Keeps track of a cache's status: members, current/pending consistent hashes, and rebalance status
ClusterCacheStatus(String, CacheJoinInfo) - Constructor for class org.infinispan.topology.ClusterCacheStatus
 
clustered - Variable in class org.infinispan.transaction.TransactionTable
 
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
 
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.
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
 
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
 
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.AbstractClusteringDependentLogic - Class in org.infinispan.interceptors.locking
 
ClusteringDependentLogic.AbstractClusteringDependentLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
ClusteringDependentLogic.DistributionLogic - Class in org.infinispan.interceptors.locking
This logic is used in distributed mode caches.
ClusteringDependentLogic.DistributionLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
ClusteringDependentLogic.InvalidationLogic - Class in org.infinispan.interceptors.locking
This logic is used in invalidation mode caches.
ClusteringDependentLogic.InvalidationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
ClusteringDependentLogic.LocalLogic - Class in org.infinispan.interceptors.locking
This logic is used in local mode caches.
ClusteringDependentLogic.LocalLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
ClusteringDependentLogic.ReplicationLogic - Class in org.infinispan.interceptors.locking
This logic is used in replicated mode caches.
ClusteringDependentLogic.ReplicationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
ClusteringInterceptor - Class in org.infinispan.interceptors
Base class for replication and distribution interceptors.
ClusteringInterceptor() - Constructor for class org.infinispan.interceptors.ClusteringInterceptor
 
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.
ClusterTopologyManager - Interface in org.infinispan.topology
Maintains the list of members and performs rebalance operations.
ClusterTopologyManagerFactory - Class in org.infinispan.topology
Factory for ClusterTopologyManager implementations
ClusterTopologyManagerFactory() - Constructor for class org.infinispan.topology.ClusterTopologyManagerFactory
 
ClusterTopologyManagerImpl - Class in org.infinispan.topology
The ClusterTopologyManager implementation.
ClusterTopologyManagerImpl() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl
 
ClusterTopologyManagerImpl.ClusterViewListener - Class in org.infinispan.topology
 
ClusterTopologyManagerImpl.ClusterViewListener() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl.ClusterViewListener
 
cm - Variable in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
CODENAME - Static variable in class org.infinispan.Version
 
coinToss - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
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.
Collector<K,V> - Interface in org.infinispan.distexec.mapreduce
OutputCollector is the intermediate key/value result data output collector given to each Mapper
combine(MapCombineCommand<KIn, VIn, KOut, VOut>, MapReduceManagerImpl.CollectableCollector<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
combinedWith(Reducer<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Specifies Combiner to use for this MapReduceTask
combiner - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
COMMAND_ID - Static variable in class org.infinispan.commands.CancelCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.control.LockControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.CreateCacheCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.DistributedExecuteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetCacheEntryCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.MapCombineCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.ReduceCommand
 
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.statetransfer.StateRequestCommand
 
COMMAND_ID - Static variable in class org.infinispan.statetransfer.StateResponseCommand
 
COMMAND_ID - Static variable in class org.infinispan.topology.CacheTopologyControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.XSiteAdminCommand
 
CommandAwareRpcDispatcher - Class in org.infinispan.remoting.transport.jgroups
A JGroups RPC dispatcher that knows how to deal with ReplicableCommands.
CommandAwareRpcDispatcher(Channel, JGroupsTransport, ExecutorService, InboundInvocationHandler, GlobalComponentRegistry, BackupReceiverRepository) - Constructor for class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
CommandInterceptor - Class in org.infinispan.interceptors.base
This is the base class for all interceptors to extend, and implements the Visitor interface allowing it to intercept invocations on VisitableCommands.
CommandInterceptor() - Constructor for class org.infinispan.interceptors.base.CommandInterceptor
 
commandsFactory - Variable in class org.infinispan.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(GlobalTransaction) - Method in class org.infinispan.loaders.AbstractCacheStore
 
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.
commitCacheEntry(CacheEntry, EntryVersion) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
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, boolean, boolean) - 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, InvocationContext) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
commitEntry(CacheEntry, EntryVersion, boolean, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
commitEntry(CacheEntry, EntryVersion, boolean, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
commitEntry(CacheEntry, EntryVersion, boolean, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
commitEntry(CacheEntry, EntryVersion, boolean, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
commonPool() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns the common pool instance.
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.
compareAndSetForkJoinTaskTag(short, short) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Atomically conditionally sets the tag value for this task.
compareAndSetPendingCount(int, int) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Sets (atomically) the pending count to the given count only if it currently holds the given expected value.
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(File) - Method in class org.infinispan.io.GridFile
 
compareTo(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
compareTo(byte[]) - Static method in class org.infinispan.Version
 
complete(T) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Regardless of pending count, invokes CountedCompleter.onCompletion(org.infinispan.util.concurrent.jdk8backported.CountedCompleter), marks this task as complete and further triggers CountedCompleter.tryComplete() on this task's completer, if one exists.
complete(V) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning the given value as the result of subsequent invocations of join and related operations.
completedTxTimeout() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
completedTxTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
The duration (millis) in which to keep information about the completion of a transaction.
completeExceptionally(Throwable) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the given exception upon join and related operations.
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
 
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.
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.BiFun<? super K, ? super V, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
compute() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
The main computation performed by this task.
computeGroup(T, String) - Method in interface org.infinispan.distribution.group.Grouper
Compute the group for a given key
computeIfAbsent(K, ConcurrentHashMapV8.Fun<? super K, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
If the specified key is not already associated with a value, attempts to compute its value using the given mapping function and enters it into this map unless null.
computeIfPresent(K, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
If the value for the specified key is present, attempts to compute a new mapping given the key and its current mapped value.
computeMaxSegments(int, int, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForMachine(int, double, Collection<TopologyInfo.Machine>, TopologyInfo.Machine) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForNode(int, double, int) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForRack(int, double, Collection<TopologyInfo.Rack>, TopologyInfo.Rack, TopologyInfo.Machine) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForSite(int, double, Collection<TopologyInfo.Site>, TopologyInfo.Site, TopologyInfo.Rack, TopologyInfo.Machine) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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.Action<A> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a void action of one argument
ConcurrentHashMapV8.BiAction<A,B> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a void action of two arguments
ConcurrentHashMapV8.BiFun<A,B,T> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function of two arguments
ConcurrentHashMapV8.ConcurrentHashMapSpliterator<T> - Interface in org.infinispan.util.concurrent.jdk8backported
An object for traversing and partitioning elements of a source.
ConcurrentHashMapV8.DoubleByDoubleToDouble - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping two doubles to a double
ConcurrentHashMapV8.Fun<A,T> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function of one argument
ConcurrentHashMapV8.IntByIntToInt - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping two ints to an int
ConcurrentHashMapV8.KeySetView<K,V> - Class in org.infinispan.util.concurrent.jdk8backported
A view of a ConcurrentHashMapV8 as a Set of keys, in which additions may optionally be enabled by mapping to a common value.
ConcurrentHashMapV8.LongByLongToLong - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping two longs to a long
ConcurrentHashMapV8.ObjectByObjectToDouble<A,B> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping two arguments to a double
ConcurrentHashMapV8.ObjectByObjectToInt<A,B> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping two arguments to an int
ConcurrentHashMapV8.ObjectByObjectToLong<A,B> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping two arguments to a long
ConcurrentHashMapV8.ObjectToDouble<A> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping its argument to a double
ConcurrentHashMapV8.ObjectToInt<A> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping its argument to an int
ConcurrentHashMapV8.ObjectToLong<A> - Interface in org.infinispan.util.concurrent.jdk8backported
Interface describing a function mapping its argument to a long
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
 
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
 
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.remoting.transport.AbstractTransport
 
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
 
ConfigurationBuilderHolder(ClassLoader) - 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
 
ConfigurationParser<T> - Interface in org.infinispan.configuration.parsing
ConfigurationParser.
ConfigurationRegistry - Interface in org.infinispan.config
A registry for Configurations.
Configurations - Class in org.infinispan.configuration.cache
Helper configuration methods.
ConfigurationUtils - Class in org.infinispan.configuration
ConfigurationUtils.
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.
 
configure() - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
configuredAsync - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.
 
configuredSync - Variable in class org.infinispan.config.Configuration.ClusteringType
Deprecated.
 
confirmRebalance(String, int, Throwable) - Method in interface org.infinispan.topology.LocalTopologyManager
Confirm that the local cache cacheName has finished receiving the new data for topology topologyId.
confirmRebalance(String, int, Throwable) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
confirmRebalanceOnNode(Address, int) - Method in class org.infinispan.topology.ClusterCacheStatus
 
consider(Collection<? extends InternalCacheEntry>) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore.CollectionGeneratingBucketHandler
 
consistentHash() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated.
consistentHash(ConsistentHash) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
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
consistentHashDeprecated() - Method in interface org.infinispan.util.logging.Log
 
consistentHashFactory() - Method in class org.infinispan.configuration.cache.HashConfiguration
The consistent hash factory in use.
consistentHashFactory(ConsistentHashFactory) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
The consistent hash factory in use.
ConsistentHashFactory<CH extends ConsistentHash> - Interface in org.infinispan.distribution.ch
Factory for ConsistentHash instances.
construct(Class<T>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.distribution.group.GroupManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.AbstractComponentFactory
Constructs a component.
construct(Class<T>) - Method in class org.infinispan.factories.BootstrapFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.DataContainerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.DistributionManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.EmptyConstructorFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.EmptyConstructorNamedCacheFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.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.StateTransferComponentFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.TestDelayFactory
 
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
 
construct(Class<T>) - Method in class org.infinispan.topology.ClusterTopologyManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.topology.LocalTopologyManagerFactory
 
constructDouble(Class<?>, Object) - Static method in class org.infinispan.util.Util
 
constructMessage(Buffer, Address, boolean, ResponseMode, boolean) - Static method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
containRemoteTx(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
contains(Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
contains(Object) - Method in class org.infinispan.util.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
Deprecated.
contains(Object) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
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.InfinispanCollections.EmptyList
 
contains(Object) - Method in class org.infinispan.util.InfinispanCollections.EmptySet
 
contains(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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
 
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
 
containsInterceptorType(Class<? extends CommandInterceptor>, boolean) - 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(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.AsyncStore
 
containsKey(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
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
 
containsKey(Object) - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
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.
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.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
 
containsValue(Object) - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
contentType - Variable in class org.infinispan.remoting.MIMECacheEntry
The MIME Content type value, for example application/octet-stream.
coordinator - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
copy() - Method in class org.infinispan.atomic.AtomicHashMap
 
copy() - Method in interface org.infinispan.atomic.CopyableDeltaAware
 
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.
CopyableDeltaAware - Interface in org.infinispan.atomic
This interface extended the DeltaAware.
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 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
 
copyWithoutRemotableFlags(Set<Flag>) - Static method in enum org.infinispan.context.Flag
Creates a copy of a Flag Set removing instances of FAIL_SILENTLY.
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
 
couldNotExecuteCancellationLocally(String) - Method in interface org.infinispan.util.logging.Log
 
couldNotFindAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
couldNotFindDescriptionField() - Method in interface org.infinispan.util.logging.Log
 
couldNotInitializeModule(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInstantiateTransactionManager(Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInterruptThread(UUID) - 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
 
couldNotResolveConfigurationSchema(String, String, String) - Method in interface org.infinispan.util.logging.Log
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
CountedCompleter<T> - Class in org.infinispan.util.concurrent.jdk8backported
A ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.
CountedCompleter(CountedCompleter<?>, int) - Constructor for class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Creates a new CountedCompleter with the given completer and initial pending count.
CountedCompleter(CountedCompleter<?>) - Constructor for class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Creates a new CountedCompleter with the given completer and an initial pending count of zero.
CountedCompleter() - Constructor for class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Creates a new CountedCompleter with no completer and an initial pending count of zero.
cr - Variable in class org.infinispan.config.AbstractNamedCacheConfigurationBean
 
create() - Method in interface org.infinispan.configuration.Builder
Create the configuration bean
create() - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
create() - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
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(Hash, int, int, List<Address>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Create a new consistent hash instance.
create(Hash, int, int, List<Address>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
create(Hash, int, int, List<Address>) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
create(Hash, int, int, List<Address>) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
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
 
createAsyncStore(CacheStore, CacheStoreConfig) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
createCache(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
This implementation clones the configuration passed in before using it.
CreateCacheCommand - Class in org.infinispan.commands
Command to create/start a cache on a subset of Infinispan cluster nodes
CreateCacheCommand(String) - Constructor for class org.infinispan.commands.CreateCacheCommand
 
CreateCacheCommand(String, String, String) - Constructor for class org.infinispan.commands.CreateCacheCommand
 
CreateCacheCommand(String, String, String, boolean, int) - Constructor for class org.infinispan.commands.CreateCacheCommand
 
createComponentFactoryInternal(Class<?>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
createComponentFactoryInternal(Class<?>, String) - Method in class org.infinispan.factories.ComponentRegistry
 
created - Variable in class org.infinispan.container.entries.MortalCacheValue
 
createDistributedTaskBuilder(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
createDistributedTaskBuilder(Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Returns DistributedTaskBuilder for this DistributedExecutorService and a given Callable.
createDistributedTaskPart(DistributedTask<T>, DistributedExecuteCommand<T>, List<K>, Address, int) - Method in class org.infinispan.distexec.DefaultExecutorService
 
createDistributedTaskPart(DistributedTask<T>, DistributedExecuteCommand<T>, Address, int) - Method in class org.infinispan.distexec.DefaultExecutorService
 
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
 
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
 
createMarshalledValue(Object, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
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 interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
createNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
createNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
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.
createReducePart(ReduceCommand<KOut, VOut>, Address, String) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
createRemoteInvocationContext(Address) - Method in interface org.infinispan.context.InvocationContextContainer
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.
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in interface org.infinispan.context.InvocationContextContainer
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createSingleKeyNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextContainer
 
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
createTaskMapPart(MapCombineCommand<KIn, VIn, KOut, VOut>, Address, boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
createTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextContainer
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 method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.
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
 
CustomFailurePolicy<K,V> - Interface in org.infinispan.xsite
Used for implementing custom policies in case of communication failures with a remote site.
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.
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.ClusteringInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
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.
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.
DataType - Enum in org.infinispan.jmx.annotations
 
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.
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
 
decOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
decPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
decrement() - Method in class org.infinispan.util.concurrent.jdk8backported.LongAdder
Equivalent to add(-1).
decrementPendingCountUnlessZero() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
If the pending count is nonzero, (atomically) decrements it.
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_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_CONCURRENCY_LEVEL - Static variable in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
DEFAULT_CONSISTENT_HASH - Static variable in interface org.infinispan.marshall.Ids
 
DEFAULT_CONSISTENT_HASH_FACTORY - 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_JGROUPS_CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
DEFAULT_LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.loaders.LockSupportCacheStoreConfig
 
DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.config.GlobalConfiguration
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_TMP_CACHE_CONFIGURATION_NAME - Static variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
DEFAULT_TRANSPORT - Static variable in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
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
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
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
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
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
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
Deprecated.
defaultChunkSize - Variable in class org.infinispan.io.GridFilesystem
 
defaultClassLoader - Variable in class org.infinispan.factories.ComponentRegistry
 
defaultClassLoader - Variable in class org.infinispan.factories.GlobalComponentRegistry
 
defaultClusteredBuilder() - Static method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultConfiguration - Variable in class org.infinispan.manager.DefaultCacheManager
 
DefaultConsistentHash - Class in org.infinispan.distribution.ch
Default ConsistentHash implementation.
DefaultConsistentHash(Hash, int, int, List<Address>, List<Address>[]) - 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
 
DefaultConsistentHashFactory - Class in org.infinispan.distribution.ch
Default implementation of ConsistentHashFactory.
DefaultConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
DefaultConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch
 
DefaultConsistentHashFactory.Builder(int, int, List<Address>) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
DefaultConsistentHashFactory.Builder(DefaultConsistentHash, List<Address>) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
DefaultConsistentHashFactory.Builder(DefaultConsistentHash) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
DefaultConsistentHashFactory.Builder(DefaultConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
DefaultConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch
 
DefaultConsistentHashFactory.Externalizer() - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.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
 
DefaultDistributedTaskLifecycle - Class in org.infinispan.distexec.spi
 
DefaultDistributedTaskLifecycle() - Constructor for class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
 
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 tasks ran on this node.
DefaultExecutorService(Cache<?, ?>, ExecutorService, boolean) - 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.
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.
defaultForkJoinWorkerThreadFactory - Static variable in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Creates a new ForkJoinWorkerThread.
defaultInterface() - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
defaultLifespan - Variable in class org.infinispan.CacheSupport
 
DefaultMapReduceTaskLifecycle - Class in org.infinispan.distexec.mapreduce.spi
 
DefaultMapReduceTaskLifecycle() - Constructor for class org.infinispan.distexec.mapreduce.spi.DefaultMapReduceTaskLifecycle
 
defaultMaxIdleTime - Variable in class org.infinispan.CacheSupport
 
DefaultRebalancePolicy - Class in org.infinispan.topology
Default implementation of RebalancePolicy
DefaultRebalancePolicy() - Constructor for class org.infinispan.topology.DefaultRebalancePolicy
 
defaultRemoteCache() - Method in class org.infinispan.configuration.cache.BackupForBuilder
Use this method if the remote cache that backups in this cache is the default cache.
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
 
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
Deprecated.
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
Deprecated.
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
defineConfiguration(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
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
delegate - Variable in class org.infinispan.atomic.AtomicHashMap
 
delegate() - Method in class org.infinispan.util.EnumerationList
 
delegate() - Method in class org.infinispan.util.ForwardingList
 
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
Deprecated.
create GridFilesystem instance with additional FORCE_SYNCHRONOUS flag, if operations should be executed synchronously
deleteOnExit() - Method in class org.infinispan.io.GridFile
 
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.
DELTA_COMPOSITE_KEY - Static variable in interface org.infinispan.marshall.Ids
 
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
 
DeltaCompositeKey - Class in org.infinispan.atomic
DeltaCompositeKey is the key guarding access to a specific entry in DeltaAware
DeltaCompositeKey(Object, Object) - Constructor for class org.infinispan.atomic.DeltaCompositeKey
 
DeltaCompositeKey.DeltaCompositeKeyExternalizer - Class in org.infinispan.atomic
 
DeltaCompositeKey.DeltaCompositeKeyExternalizer() - Constructor for class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
 
deltaMapKey - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
deltas - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
deprecatedLoaderAsStoreConfiguration() - Method in interface org.infinispan.util.logging.Log
 
deserialize() - Method in class org.infinispan.marshall.MarshalledValue
 
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
detectScope(Class<?>) - Static method in class org.infinispan.factories.scopes.ScopeDetector
 
difference(Set<E>, Set<E>) - Static method in class org.infinispan.util.InfinispanCollections
Returns the elements that are present in s1 but which are not present in s2, without changing the contents of neither s1, nor s2.
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.AsyncStoreConfigurationBuilder
 
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
 
disableBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns true if this cache won't backup its data remotely.
disableBackups(boolean) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
Returns true if this cache won't backup its data remotely.
disableCacheLoader(String) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
disableCacheStore(String) - Method in interface org.infinispan.loaders.CacheLoaderManager
 
disableCacheStore(String) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
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
disableInterceptor() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
disableInterceptor() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
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
 
disconnectSource(String) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
disconnectSource(Cache<Object, Object>) - Method in interface org.infinispan.upgrade.TargetMigrator
Disconnects the target from the source.
DisplayType - Enum in org.infinispan.jmx.annotations
 
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(String) - Constructor for class org.infinispan.commands.read.DistributedExecuteCommand
 
DistributedExecuteCommand(String, 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.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.
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.
distributedSyncTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Timeout for coordinating cluster formation when nodes join or leave the cluster.
DistributedTask<T> - Interface in org.infinispan.distexec
DistributedTask describes all relevant attributes of a distributed task, most importantly its execution policy, fail over policy and its timeout.
DistributedTaskBuilder<T> - Interface in org.infinispan.distexec
DistributedTaskBuilder is a factory interface for DistributedTask
DistributedTaskExecutionPolicy - Enum in org.infinispan.distexec
DistributedTaskExecutionPolicy allows task to specify its custom task execution policy across Infinispan cluster.
DistributedTaskFailoverPolicy - Interface in org.infinispan.distexec
DistributedTaskFailoverPolicy allows pluggable fail over target selection for a failed remotely executed distributed task.
DistributedTaskLifecycle - Interface in org.infinispan.distexec.spi
 
DistributedTaskLifecycleService - Class in org.infinispan.distexec.spi
 
distributeReducePhase - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
distributeReducePhase() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
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.interceptors.distribution.BaseDistributionInterceptor
 
doAddBackupOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
doAddPrimaryOwners(DefaultConsistentHashFactory.Builder, int, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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
 
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)
doRemoveExtraBackupOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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
 
drainReplQueue() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status.
DummyBaseTransactionManager - Class in org.infinispan.transaction.tm
 
DummyBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
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
 
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

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
Element - Enum in org.infinispan.configuration.as
An enumeration of all the recognized XML element local names, by name.
Element - Enum in org.infinispan.configuration.parsing
An enumeration of all the recognized XML element local names, by name.
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_BYTE_ARRAY - Static variable in class org.infinispan.util.Util
 
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_LIST - Static variable in interface org.infinispan.marshall.Ids
 
EMPTY_MAP - Static variable in interface org.infinispan.marshall.Ids
 
EMPTY_OBJECT_ARRAY - Static variable in class org.infinispan.util.Util
 
EMPTY_PRIORITIZED_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
EMPTY_SET - Static variable in interface org.infinispan.marshall.Ids
 
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
 
emptyList() - Static method in class org.infinispan.util.InfinispanCollections
Returns the empty list (immutable).
emptyMap() - Static method in class org.infinispan.util.InfinispanCollections
Returns the empty map (immutable).
emptySet() - Static method in class org.infinispan.util.InfinispanCollections
Returns the empty set (immutable).
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.AsyncStoreConfigurationBuilder
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(boolean) - 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
 
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.AsyncStoreConfiguration
If true, all modifications to this cache store happen asynchronously, on a separate thread.
enabled(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Configures whether this site is used for backing up data or not (defaults to true).
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.StoreAsBinaryConfiguration
 
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.TakeOfflineConfiguration
 
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.interceptors.CacheLoaderInterceptor
 
enabled - Variable in class org.infinispan.interceptors.CacheStoreInterceptor
 
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.
enabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns the list of BackupConfiguration that have BackupConfiguration.enabled() == true.
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
 
endRebalance() - Method in class org.infinispan.topology.ClusterCacheStatus
 
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.
entries - Variable in class org.infinispan.container.DefaultDataContainer
 
entriesMigrated(long, String, String) - Method in interface org.infinispan.util.logging.Log
 
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.
entryFactory - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
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 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
 
entrySet() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
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.atomic.DeltaCompositeKey
 
equals(Object) - Method in class org.infinispan.atomic.PutOperation
 
equals(Object) - Method in class org.infinispan.commands.CancelCommand
 
equals(Object) - Method in class org.infinispan.commands.control.LockControlCommand
 
equals(Object) - Method in class org.infinispan.commands.CreateCacheCommand
 
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.MapCombineCommand
 
equals(Object) - Method in class org.infinispan.commands.read.ReduceCommand
 
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.commons.hash.MurmurHash2
 
equals(Object) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
equals(Object) - Method in class org.infinispan.commons.hash.MurmurHash3
 
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.AbstractLockSupportStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AsyncConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
equals(Object) - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
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.LegacyLoaderConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.LegacyStoreConfiguration
 
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.SitesConfiguration
 
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.TakeOfflineConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
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.SiteConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.parsing.Namespace
 
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.mapreduce.MapReduceManagerImpl.IntermediateCompositeKey
 
equals(Object) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
equals(Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
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.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.marshall.MarshalledValue
 
equals(Object) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
equals(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
equals(Object) - Method in class org.infinispan.remoting.MIMECacheEntry
 
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.AggregateBackupResponse
 
equals(Object) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
equals(Object) - Method in class org.infinispan.topology.CacheTopology
 
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.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.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
 
equals(Object) - Method in class org.infinispan.util.ForwardingList
 
equals(Object) - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
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.
errorChangingSingletonStoreStatus(SingletonStore.PushStateException) - Method in interface org.infinispan.util.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
 
errorDoingRemoteCall(Exception) - 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
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.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
 
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
 
errorRollingBack(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorSavingBucket(Bucket, IOException) - Method in interface org.infinispan.util.logging.Log
 
errorUnblockingTransactions(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorUpdatingMembersList(Throwable) - 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.
estimateSize() - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
Returns an estimate of the number of elements covered by this Spliterator.
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
 
EvictCommand - Class in org.infinispan.commands.write
 
EvictCommand(Object, CacheNotifier, Set<Flag>) - 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(Long) - Method in interface org.infinispan.util.logging.Log
 
EXCEPTION_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionPurgingDataContainer(Exception) - Method in interface org.infinispan.util.logging.Log
 
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
 
exec() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Implements execution conventions for CountedCompleters.
exec() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Immediately performs the base action of this task and returns true if, upon return from this method, this task is guaranteed to have completed normally.
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(ExecutorService) - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
execute() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invokes eviction policy algorithm and returns set of evicted entries.
execute(ForkJoinTask<?>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
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
executeIfKeyIsNotUpdated(Object, Runnable) - Method in interface org.infinispan.statetransfer.StateConsumer
Run a callback only if the key was not updated by user code, and prevent user code from updating the key while running the callback.
executeIfKeyIsNotUpdated(Object, Runnable) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
executeMapPhase(boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
executeMapPhaseWithLocalReduction() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
executeReducePhase(Set<KOut>, boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
executeTaskInit(String) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
executionCandidates(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
executionCandidates() - Method in interface org.infinispan.distexec.FailoverContext
Returns a list of candidates for possible repeated execution governed by installed DistributedTaskFailoverPolicy
executionError(Throwable) - Method in interface org.infinispan.util.logging.Log
 
executionFailureLocation() - Method in interface org.infinispan.distexec.FailoverContext
Returns an Address of the node where the task failed
executionPolicy(DistributedTaskExecutionPolicy) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
Provide DistributedTaskExecutionPolicy for the task being built
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.
exists() - Method in class org.infinispan.io.GridFile
 
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 by 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
 
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.
ExposedByteArrayOutputStream - Class in org.infinispan.io
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
exposeJmxStats - Variable in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
EXTENDED_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
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
 
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.
 
extractFieldName(String) - Static method in class org.infinispan.util.ReflectionUtil
 
extractProperties(Element) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
 

F

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
 
failAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
failedInvalidatingRemoteCache(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingKeysFromCacheStore(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingValueFromCacheStore(Object, Exception) - 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
 
failedToRecoverCacheState(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRecoverClusterState(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRequestSegments(Collection<Integer>, String, Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToRetrieveTransactionsForSegments(Collection<Integer>, String, Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToUpdateAtribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
failover(FailoverContext) - Method in interface org.infinispan.distexec.DistributedTaskFailoverPolicy
As parts of distributively executed task can fail due to the task itself throwing an exception or it can be an Infinispan system caused failure (e.g node failed or left cluster during task execution etc).
FailoverContext - Interface in org.infinispan.distexec
As DistributedTask might potentially fail on subset of executing nodes FailureContext provides details of such task failure.
failoverPolicy(DistributedTaskFailoverPolicy) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
Provide DistributedTaskFailoverPolicy for the task being built
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.TransactionTable
 
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
failurePolicyClass() - Method in class org.infinispan.configuration.cache.BackupConfiguration
If the failure policy is set to BackupFailurePolicy.CUSTOM then the failurePolicyClass is required and should return the fully qualified name of a class implementing CustomFailurePolicy
failurePolicyClass() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
If the failure policy is set to BackupFailurePolicy.CUSTOM then the failurePolicyClass is required and should return the fully qualified name of a class implementing CustomFailurePolicy
failurePolicyClass(String) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
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
 
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.AbstractStoreConfiguration
If true, fetch persistent state when joining a cluster.
fetchPersistentState - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
If true, fetch persistent state when joining a cluster.
fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
fetchPersistentState() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
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(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
If true, fetch persistent state when joining a cluster.
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
 
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
 
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
 
FileCacheStoreConfigurationBuilder.FsyncModeEditor - Class in org.infinispan.configuration.cache
Deprecated.
FileCacheStoreConfigurationBuilder.FsyncModeEditor() - Constructor for class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder.FsyncModeEditor
Deprecated.
 
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
 
filename(String) - Static method in class org.infinispan.io.GridFile
 
fillInStackTrace() - Method in exception org.infinispan.marshall.NotSerializableException
 
filterLocalPrimaryOwner(Set<KIn>, DistributionManager) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
findComponentMetadata(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates metadata for a given component type if registered.
findComponentMetadata(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates metadata for a given component type if registered.
findFactoryForComponent(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates the fully qualified class name of a factory capable of constructing an instance of
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
 
findNewBackupOwner(DefaultConsistentHashFactory.Builder, Collection<Address>, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
findNewPrimaryOwner(DefaultConsistentHashFactory.Builder, Collection<Address>, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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
 
fireParsingComplete() - Method in class org.infinispan.configuration.parsing.AbstractParserContext
 
fireParsingComplete() - Method in interface org.infinispan.configuration.parsing.ParserContext
 
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
 
firstComplete() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
If this task's pending count is zero, returns this task; otherwise decrements its pending count and returns null.
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransactionManager
 
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 - Interface in org.infinispan.context
Deprecated.
No longer used since 5.2.0
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
 
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.
fluentSetterName(String) - Static method in class org.infinispan.util.BeanUtils
Retrieves a setter name based on a field name passed in
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 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>, Address, boolean) - Method in interface org.infinispan.distribution.L1Manager
 
flushCache(Collection<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
 
flushL1Caches(InvocationContext) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
flushLockTimeout() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
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.AsyncStoreConfiguration
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.AsyncStoreConfigurationBuilder
Timeout to acquire the lock which guards the state to be flushed to the cache store periodically.
flushLockTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
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.
forCacheMode(CacheMode) - Static method in enum org.infinispan.configuration.as.Mode
 
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
 
forceOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
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
forceTransactionCompletionFromCluster(Xid, Address, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
forEach(ConcurrentHashMapV8.BiAction<? super K, ? super V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
 
forEach(long, ConcurrentHashMapV8.BiAction<? super K, ? super V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each (key, value).
forEach(long, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each non-null transformation of each (key, value).
forEach(ConcurrentHashMapV8.Action<? super K>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
 
forEachEntry(long, ConcurrentHashMapV8.Action<? super Map.Entry<K, V>>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each entry.
forEachEntry(long, ConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each non-null transformation of each entry.
forEachKey(long, ConcurrentHashMapV8.Action<? super K>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each key.
forEachKey(long, ConcurrentHashMapV8.Fun<? super K, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each non-null transformation of each key.
forEachRemaining(ConcurrentHashMapV8.Action<? super T>) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
Applies the action to each untraversed element
forEachValue(long, ConcurrentHashMapV8.Action<? super V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each value.
forEachValue(long, ConcurrentHashMapV8.Fun<? super V, ? extends U>, ConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Performs the given action for each non-null transformation of each value.
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
 
fork() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Arranges to asynchronously execute this task in the pool the current task is running in, if applicable, or using the ForkJoinPool.commonPool() if not ForkJoinTask.inForkJoinPool().
ForkJoinPool - Class in org.infinispan.util.concurrent.jdk8backported
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Creates a ForkJoinPool with parallelism equal to Runtime.availableProcessors(), using the default thread factory, no UncaughtExceptionHandler, and non-async LIFO processing mode.
ForkJoinPool(int) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Creates a ForkJoinPool with the indicated parallelism level, the default thread factory, no UncaughtExceptionHandler, and non-async LIFO processing mode.
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Creates a ForkJoinPool with the given parameters.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in org.infinispan.util.concurrent.jdk8backported
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in org.infinispan.util.concurrent.jdk8backported
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinTask<V> - Class in org.infinispan.util.concurrent.jdk8backported
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
 
ForkJoinWorkerThread - Class in org.infinispan.util.concurrent.jdk8backported
A thread managed by a ForkJoinPool, which executes ForkJoinTasks.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class org.infinispan.util.concurrent.jdk8backported.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.
formatString(Object, Object...) - Static method in class org.infinispan.util.Util
 
forName(String) - Static method in enum org.infinispan.configuration.as.Attribute
 
forName(String) - Static method in enum org.infinispan.configuration.as.Element
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Element
 
forwardCommandIfNeeded(TopologyAffectedCommand, Set<Object>, Address, boolean) - Method in interface org.infinispan.statetransfer.StateTransferManager
If there is an state transfer happening at the moment, this method forwards the supplied command to the nodes that are new owners of the data, in order to assure consistency.
forwardCommandIfNeeded(TopologyAffectedCommand, Set<Object>, Address, boolean) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
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.
frequency - Variable in class org.infinispan.config.Configuration.L1Type
Deprecated.
 
friendlyCacheModeString() - Method in enum org.infinispan.configuration.cache.CacheMode
 
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 interface org.infinispan.loaders.CacheStore
Writes contents of the stream to the store.
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
fromStream(ObjectInput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
fromStream(byte, Object[], byte, String) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
fromStreamLockSafe(ObjectInput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
fsyncInterval() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfiguration
 
fsyncInterval(long) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
fsyncInterval(long, TimeUnit) - 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
 
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
 
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(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.marshall.MarshalledValue
Returns the 'cached' instance
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.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.jdk8backported.ForkJoinTask
Waits if necessary for the computation to complete, and then retrieves its result.
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
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.NotifyingFutureAdaptor
 
get(long, TimeUnit) - Method in class org.infinispan.util.concurrent.NotifyingFutureAdaptor
 
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(int) - Method in class org.infinispan.util.InfinispanCollections.EmptyList
 
get(Object) - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
getAbsoluteFile() - Method in class org.infinispan.io.GridFile
 
getAbsolutePath() - Method in class org.infinispan.io.GridFile
 
getActivationCount() - Method in interface org.infinispan.eviction.ActivationManager
Get number of activations executed.
getActivationCount() - Method in class org.infinispan.eviction.ActivationManagerImpl
 
getActivations() - Method in class org.infinispan.eviction.ActivationManagerImpl
 
getActiveThreadCount() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns an estimate of the number of threads that are currently stealing or executing tasks.
getActualNumOwners() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getActualNumOwners() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
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.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
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() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the address associated with this RpcManager or null if not part of the cluster.
getAddress() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getAddress() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's network address
getAddress() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getAddress2KeysMapping() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getAdvancedCache() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getAdvancedCache() - Method in class org.infinispan.AbstractDelegatingCache
 
getAdvancedCache() - Method in interface org.infinispan.Cache
 
getAdvancedCache() - Method in class org.infinispan.CacheImpl
 
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.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
 
getAllMachinesCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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.
getAllModifications() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getAllModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns all the modifications visible within the current transaction, including those using Flag#CACHE_MODE_LOCAL.
getAllNodesCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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
 
getAllOwners() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getAllRacksCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllSites() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllSitesCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAnnotatedFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.util.ReflectionUtil
 
getAnnotation(Class<?>, Class<T>) - Static method in class org.infinispan.util.ReflectionUtil
Inspects the class passed in for the class level annotation specified.
getAsInputStreamFromClassLoader(String, 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.DecoratedCache
 
getAsyncListenerExecutorFactoryClass() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
 
getAsyncListenerExecutorProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
 
getAsyncMode() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns true if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
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
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
 
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.
 
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
 
getBackupCacheManager(String, String) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
Returns the local cache associated defined as backup for the provided remote (site, cache) combo, or throws an exception of no such site is defined.
getBackupLockedKeys() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getBackupLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getBackupOwners(int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getBackupReceiver(String, String) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
getBase() - Method in class org.infinispan.configuration.parsing.Namespace
 
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
 
getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
 
getBefore() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getBeforeInterceptor() - Method in class org.infinispan.config.CustomInterceptorConfig
 
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
 
getBuf() - Method in class org.infinispan.io.ByteBuffer
 
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.
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, 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() - Method in interface org.infinispan.xsite.BackupReceiver
 
getCache() - Method in class org.infinispan.xsite.BackupReceiverImpl
 
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.
getCacheEntries() - Method in class org.infinispan.statetransfer.StateChunk
 
getCacheEntry(Object, EnumSet<Flag>, ClassLoader) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getCacheEntry(Object, EnumSet<Flag>, ClassLoader) - Method in interface org.infinispan.AdvancedCache
Retrieves a CacheEntry corresponding to a specific key
getCacheEntry(Object, EnumSet<Flag>, ClassLoader) - Method in class org.infinispan.CacheImpl
 
getCacheEntry() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
GetCacheEntryCommand - Class in org.infinispan.commands.read
An internal cache get command that returns CacheEntry instead of just the value.
GetCacheEntryCommand(Object, Set<Flag>) - Constructor for class org.infinispan.commands.read.GetCacheEntryCommand
 
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
getCacheLoaderMisses() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaders() - Method in class org.infinispan.config.Configuration
Deprecated.
 
getCacheLoaders() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaders(Class<T>) - Method in interface org.infinispan.loaders.CacheLoaderManager
 
getCacheLoaders(Class<T>) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
getCacheLoaders(Class<T>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
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 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 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.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
 
getCacheName() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getCacheName() - Method in interface org.infinispan.upgrade.SourceMigrator
 
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.
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
 
getCacheTopology() - Method in interface org.infinispan.statetransfer.StateConsumer
 
getCacheTopology() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
getCacheTopology() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
getCacheTopology() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
getCacheTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getCacheTopology(String) - Method in interface org.infinispan.topology.LocalTopologyManager
 
getCacheTopology(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
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
 
getCallable() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getCallable() - Method in interface org.infinispan.distexec.DistributedTask
Returns Callable for this task
getCanonicalFile() - Method in class org.infinispan.io.GridFile
 
getCanonicalPath() - Method in class org.infinispan.io.GridFile
 
getChangeLogSize() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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.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.configuration.parsing.ConfigurationBuilderHolder
 
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.SingleKeyNonTxInvocationContext
 
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
 
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
 
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.
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
 
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
 
getCombiner() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getCommand() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommandAwareRpcDispatcher() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCommandId() - Method in class org.infinispan.commands.CancelCommand
 
getCommandId() - Method in class org.infinispan.commands.control.LockControlCommand
 
getCommandId() - Method in class org.infinispan.commands.CreateCacheCommand
 
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.GetCacheEntryCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getCommandId() - Method in class org.infinispan.commands.read.ReduceCommand
 
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.statetransfer.StateRequestCommand
 
getCommandId() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
getCommandId() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getCommandId() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
getCommands() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
getCommandsFactory() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getLocalComponent(CommandsFactory.class);
getCommitNodes(Collection<Address>, int, Collection<Address>) - Method in class org.infinispan.transaction.LocalTransaction
Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare was sent.
getCommits() - Method in class org.infinispan.interceptors.TxInterceptor
 
getCommittedViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getCommonPoolParallelism() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns the targeted parallelism level of the common pool.
getCommunicationErrors() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getCommunicationErrors() - Method in interface org.infinispan.remoting.transport.BackupResponse
Returns the list of sites where the backups failed due to a bridge communication error (as opposed to an error caused by Infinispan, e.g.
getCommunicationErrors() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
getCompleter() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Returns the completer established in this task's constructor, or null if none.
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
 
getComponentMetadataRepo() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getComponentMetadataRepo() - Method in class org.infinispan.factories.ComponentRegistry
 
getComponentMetadataRepo() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
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
 
getConfiguration() - Method in class org.infinispan.AbstractDelegatingCache
 
getConfiguration() - Method in interface org.infinispan.Cache
Deprecated.
getConfiguration() - Method in class org.infinispan.CacheImpl
Deprecated.
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 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.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
 
getConfigurationNames() - Method in interface org.infinispan.config.ConfigurationRegistry
Gets the names of all registered configurations.
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 interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
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
getConsistentHashClass() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.
 
getConsistentHashFactory() - Method in class org.infinispan.topology.CacheJoinInfo
 
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
 
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
 
getCurrentCH() - Method in class org.infinispan.topology.CacheTopology
The current consistent hash.
getCurrentCH() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getCurrentConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
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
 
getCurrentSocketBindingGroup() - Method in class org.infinispan.configuration.as.ParserContextAS7
 
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 class org.infinispan.util.ByteArrayKey
 
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.
 
getDeadlockDetectionSpinDuration() - Method in class org.infinispan.config.Configuration
Deprecated.
 
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.
Use EmbeddedCacheManager.getDefaultCacheConfiguration() instead. Please note that before this method was deprecated, modifications on the Configuration returned would be applied to the default cache if it was not started. Since the deprecation, this method returns a copy and so any changes to the returned object won't have any impact on the default cache instance.
getDefaultConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
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
 
getDelta() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getDeltaAwareValueKey() - Method in class org.infinispan.atomic.DeltaCompositeKey
 
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
 
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.JmxOperationParameter
 
getDescription() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getDestination() - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
getDetectedLocalDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getDetectedRemoteDeadlocks() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
getDistinctLocationsCount(TopologyLevel, int) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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
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
 
getEnabled() - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.
 
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
 
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
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getException() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns the exception thrown by the base computation, or a CancellationException if cancelled, or null if none or if the method has not yet completed.
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in interface org.infinispan.executors.ExecutorFactory
 
getExecutorService() - Method in interface org.infinispan.distexec.mapreduce.MapReduceManager
ExecutorService provided for local task execution
getExecutorService() - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
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.
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.
 
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.
getFactory(Class<?>) - Method in class org.infinispan.factories.ComponentRegistry
 
getFactory() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns the factory used for constructing new workers.
getFailedBackups() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getFailedBackups() - Method in interface org.infinispan.remoting.transport.BackupResponse
 
getFailedBackups() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
getFailureCount() - Method in class org.infinispan.xsite.OfflineStatus
 
getFailurePolicy(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
getField(String, Class<?>) - Static method in class org.infinispan.util.ReflectionUtil
 
getFieldName() - Method in class org.infinispan.config.Configuration.BooleanAttributeType
Deprecated.
 
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
 
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
 
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
Deprecated.
 
getFlags() - Method in class org.infinispan.DecoratedCache
 
getFlushLockTimeout() - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
 
getForkJoinTaskTag() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns the tag for this task.
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
 
getFreeSpace() - Method in class org.infinispan.io.GridFile
 
getFsyncInterval() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
getFsyncMode() - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
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
Deprecated.
Use EmbeddedCacheManager.getCacheManagerConfiguration() instead. Please note that before this method was deprecated, modifications on the GlobalConfiguration returned would be applied to the cache manager if it was not started. Since the deprecation, this method returns a copy and so any changes to the returned object won't have any impact on the cache manager instance.
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.notifications.cachelistener.event.EventImpl
 
getGlobalTransaction() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
 
getGlobalTransaction() - Method in class org.infinispan.statetransfer.TransactionInfo
 
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
 
getGroups() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.
 
getHashFunction() - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
getHashFunction() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getHashFunction() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getHashFunction() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getHashFunction() - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
getHashFunction() - Method in class org.infinispan.topology.CacheJoinInfo
 
getHashFunctionClass() - Method in class org.infinispan.config.Configuration
Deprecated.
 
getHashFunctionClass() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.
 
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.
 
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.DeltaCompositeKey.DeltaCompositeKeyExternalizer
 
getId() - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
getId() - Method in class org.infinispan.atomic.RemoveOperation.Externalizer
 
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.DefaultConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.loaders.bucket.Bucket.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.remoting.responses.CacheNotFoundResponse.Externalizer
 
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.StateChunk.Externalizer
 
getId() - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
getId() - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
getId() - Method in class org.infinispan.topology.CacheTopology.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
 
getId() - Method in class org.infinispan.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
getId() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
getId() - Method in class org.infinispan.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
getIndex() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getIndexingProperties() - Method in class org.infinispan.config.Configuration
Deprecated.
 
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.
getInstance() - Static method in class org.infinispan.container.entries.NullMarkerEntry
 
getInstance() - Static method in class org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycleService
 
getInstance() - Static method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
 
getInstance() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getInstance(ComponentRegistry, Configuration) - Static method in class org.infinispan.factories.InterceptorChainFactory
 
getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
getInstance() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getInstance(Class<T>) - Static method in class org.infinispan.util.Util
Instantiates a class by first attempting a static factory method named getInstance() on the class and then falling back to an empty constructor.
getInstance(String, 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.
getInterceptorsWithClass(Class) - 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.
getInterface(String) - Method in class org.infinispan.configuration.as.ParserContextAS7
 
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.util.LegacyKeySupportTypedProperties
 
getIntProperty(String, int) - Method in class org.infinispan.util.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.util.TypedProperties
 
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
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.
 
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
 
getJoiners() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getJoinInfo() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getKey() - Method in interface org.infinispan.affinity.KeyGenerator
 
getKey() - Method in class org.infinispan.affinity.RndKeyGenerator
 
getKey() - Method in interface org.infinispan.commands.DataCommand
 
getKey() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getKey() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getKey() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKey() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getKey() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the key to this entry
getKey() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getKey() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
getKey() - Method in class org.infinispan.loaders.modifications.Remove
 
getKey() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
getKey() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getKey() - Method in class org.infinispan.util.AbstractMap.SimpleEntry
 
getKey() - Method in class org.infinispan.util.SimpleImmutableEntry
 
getKeyForAddress(Address) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the cluster node identified by address.
getKeyForAddress(Address) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getKeyMapping(String) - Method in class org.infinispan.loaders.keymappers.DefaultTwoWayKey2StringMapper
 
getKeyMapping(String) - Method in class org.infinispan.loaders.keymappers.MarshalledValueOrPrimitiveMapper
 
getKeyMapping(String) - Method in interface org.infinispan.loaders.keymappers.TwoWayKey2StringMapper
Maps a String back to its original key
getKeys() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getKeys() - Method in class org.infinispan.commands.control.LockControlCommand
 
getKeys() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getKeys() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getKeys() - Method in class org.infinispan.commands.read.ReduceCommand
 
getKeys() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getKeys() - Method in class org.infinispan.commands.write.InvalidateCommand
 
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, 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.
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getLength() - Method in class org.infinispan.io.ByteBuffer
 
getLength() - Method in class org.infinispan.io.GridFile.Metadata
 
getLength() - Static method in class org.infinispan.Version
 
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
 
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
 
getLocalAddress() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getLocalAddress() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getLocalCacheName() - Method in exception org.infinispan.xsite.BackupFailureException
 
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.as.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.configuration.as.Element
Get the local name of this element.
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(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
Looks up a LocalTransaction given a GlobalTransaction.
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
 
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.file.FileCacheStoreConfig
 
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(FlagAffectedCommand, boolean) - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
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.SingleKeyNonTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.statetransfer.TransactionInfo
 
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.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.SingleKeyNonTxInvocationContext
 
getLocksHeldAtOrigin() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
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.distribution.BaseDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
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.TxInterceptor
 
getLog() - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.VersionedReplicationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
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.remoting.transport.jgroups.JGroupsTransport
 
getLog() - Method in interface org.infinispan.remoting.transport.Transport
 
getLog() - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
getLog() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
 
getLog() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
getLog() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
getLog() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
getLog() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
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.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.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
 
getLookedUpRemoteVersion(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getLookedUpRemoteVersion(Object) - 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
 
getMachineNodes(String, String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getMajor() - Method in class org.infinispan.configuration.parsing.Namespace
 
getMap() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMappedValue() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
Returns the default mapped value for additions, or null if additions are not supported.
getMapper() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getMarshaller() - Method in class org.infinispan.loaders.AbstractCacheStore
 
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.
 
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
 
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.distexec.DefaultExecutorService
 
getMembers() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Should return the addresses of the nodes used to create this consistent hash.
getMembers() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getMembers() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getMembers() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getMembers() - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
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 interface org.infinispan.remoting.rpc.RpcManager
Returns members of a cluster scoped to the cache owning this RpcManager.
getMembers() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMembers() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getMembers() - Method in interface org.infinispan.remoting.transport.Transport
Returns a list of members in the current cluster view.
getMembers() - Method in class org.infinispan.topology.CacheTopology
 
getMembers() - Method in class org.infinispan.topology.ClusterCacheStatus
 
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
 
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
 
getMinor() - Method in class org.infinispan.configuration.parsing.Namespace
 
getMinTopologyId() - 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
 
getMode() - Method in enum org.infinispan.configuration.as.TransactionMode
 
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 the modifications performed in the scope of the current transaction.
getModifications() - Method in class org.infinispan.statetransfer.TransactionInfo
 
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.
getModificationTime() - Method in class org.infinispan.io.GridFile.Metadata
 
getModuleCommandFactory() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
getModuleCommandInitializer() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
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.
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
 
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.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.factories.components.JmxOperationParameter
 
getName() - Method in class org.infinispan.io.GridFile
 
getName() - Method in class org.infinispan.manager.DefaultCacheManager
 
getName() - Method in interface org.infinispan.upgrade.TargetMigrator
Returns the name of this migrator
getNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedConfigurationBuilders() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
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.
getNewMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getNewMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Gets the current list of members.
getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getNewTopologyId() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getNewValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Retrieves the next interceptor in the chain.
getNodeAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNodeName() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
 
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 class org.infinispan.distribution.ch.DefaultConsistentHash
 
getNormalizedHash(Object, Hash) - Static method in class org.infinispan.util.Util
Applies the given hash function to the hash code of a given object, and then normalizes it to ensure a positive value is always returned.
getNumberOfEntries() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getNumberOfLocksAvailable() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumberOfLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the number of locks currently held.
getNumberOfLocksHeld() - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
getNumEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
getNumLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
getNumNodes() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getNumOwners() - Method in class org.infinispan.config.Configuration
Deprecated.
 
getNumOwners() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.
 
getNumOwners() - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getNumOwners() - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
getNumOwners() - Method in class org.infinispan.topology.CacheJoinInfo
 
getNumRetries() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.
 
getNumSegments() - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getNumSegments() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getNumSegments() - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
getNumSegments() - Method in class org.infinispan.topology.CacheJoinInfo
 
getNumVirtualNodes() - Method in class org.infinispan.config.Configuration
Deprecated.
 
getNumVirtualNodes() - Method in class org.infinispan.config.Configuration.HashType
Deprecated.
 
getObjectName(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName(String, String, String) - Static method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName() - Method in class org.infinispan.jmx.ResourceDMBean
 
getObjectWriter(Object) - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
getOfflineStatus(String) - Method in interface org.infinispan.xsite.BackupSender
 
getOfflineStatus(String) - Method in class org.infinispan.xsite.BackupSenderImpl
 
getOffset() - Method in class org.infinispan.io.ByteBuffer
 
getOldMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getOldMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Gets the previous list of members.
getOldValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getOperationMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getOperationName() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getOperationName() - Method in class org.infinispan.jmx.IspnMBeanOperationInfo
 
getOrCreateComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves a component if one exists, and if not, attempts to find a factory capable of constructing the component (factories annotated with the DefaultFactoryFor annotation that is capable of creating the component class).
getOrCreateComponent(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getOrCreateLocalTransaction(Transaction, TxInvocationContext) - Method in class org.infinispan.transaction.TransactionTable
Returns the TransactionXaAdapter corresponding to the supplied transaction.
getOrCreateRemoteTransaction(GlobalTransaction, WriteCommand[]) - Method in class org.infinispan.transaction.TransactionTable
Returns an existing remote transaction or creates one if none exists.
getOrDefault(Object, V) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the value to which the specified key is mapped, or the given default value if this map contains no mapping for the key.
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.SingleKeyNonTxInvocationContext
 
getOrigin() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getOutboundSocketBinding(String) - Method in class org.infinispan.configuration.as.ParserContextAS7
Searches for the named OutboundSocketBinding in all SocketBindingGroups
getOutboundSocketBinding(String) - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
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
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
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
 
getOwner() - Method in class org.infinispan.util.concurrent.locks.VisibleOwnerReentrantLock
 
getOwners(int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getOwners(int) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
getOwners(Collection<Object>) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
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.
getParallelism() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns the targeted parallelism level of this pool.
getParameterClasses() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getParameterName(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
getParameters() - Method in class org.infinispan.commands.CancelCommand
 
getParameters() - Method in class org.infinispan.commands.control.LockControlCommand
 
getParameters() - Method in class org.infinispan.commands.CreateCacheCommand
 
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.MapCombineCommand
 
getParameters() - Method in class org.infinispan.commands.read.ReduceCommand
 
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.statetransfer.StateRequestCommand
 
getParameters() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
getParameters() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getParameters() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
getParent() - Method in class org.infinispan.io.GridFile
 
getParentFile() - Method in class org.infinispan.io.GridFile
 
getParserContext(Class<? extends ConfigurationParser<?>>) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getPassivationCount() - Method in interface org.infinispan.eviction.PassivationManager
 
getPassivationCount() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
getPassivations() - Method in class org.infinispan.interceptors.PassivationInterceptor
 
getPath() - Method in class org.infinispan.io.GridFile
Returns path of this file.
getPendingCH() - Method in class org.infinispan.topology.CacheTopology
The future consistent hash.
getPendingCH() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getPendingCount() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Returns the current pending count.
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.
getPool() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns the pool hosting the current task execution, or null if this task is executing outside of any ForkJoinPool.
getPool() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinWorkerThread
Returns the index number of this thread in its pool.
getPoolSize() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPosition() - Method in class org.infinispan.config.CustomInterceptorConfig
 
getPositionAsString() - Method in class org.infinispan.config.CustomInterceptorConfig
 
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
 
getPreparingTxs() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
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
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
getPrimaryOwner(int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
getPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
getPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
getPrimaryOwner() - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
getPriority() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
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
 
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.
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
 
getQueuedSubmissionCount() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns an estimate of the total number of tasks currently held in queues by worker threads (but not including tasks submitted to the pool that have not begun executing).
getQueuedTaskCount() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
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
 
getRackMachines(String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getRackNodes(String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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.
getRawResult() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Returns the result of the computation.
getRawResult() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns the result that would be returned by ForkJoinTask.join(), even if this task completed abnormally, or null if this task is not known to have been completed.
getReadableChannel(String) - Method in class org.infinispan.io.GridFilesystem
Opens a ReadableGridFileChannel for reading from the file denoted by the given file path.
getReadConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
 
getReadConsistentHash() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getReadConsistentHash() - Method in class org.infinispan.topology.CacheTopology
Read operations should always go to the "current" members.
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
 
getRecoveryInfoCacheName() - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.
 
getRecoveryManager() - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getReducer() - Method in class org.infinispan.commands.read.ReduceCommand
 
getReferenceCounter() - Method in class org.infinispan.util.concurrent.locks.OwnableRefCountingReentrantLock
 
getReferenceCounter() - Method in interface org.infinispan.util.concurrent.locks.RefCountingLock
Accesses the reference counter for this lock
getReferenceCounter() - Method in class org.infinispan.util.concurrent.locks.VisibleOwnerRefCountingReentrantLock
 
getReferencedObject(int) - Method in class org.infinispan.marshall.UnmarshalledReferences
Retrieves an object referenced by an id
getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Returns an immutable set 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.
 
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
 
getRemotelyFetchedValue() - Method in class org.infinispan.commands.read.GetKeyValueCommand
If the cache needs to go remotely in order to obtain the value associated to this key, then the remote value is stored in this field.
getRemoteSiteNames() - Method in exception org.infinispan.xsite.BackupFailureException
 
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.
 
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
 
getResponseFromPrimaryOwner(Address, Map<Address, Response>) - Method in class org.infinispan.interceptors.distribution.NonTxConcurrentDistributionInterceptor
 
getResponseFromPrimaryOwner(Address, Map<Address, Response>) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
getResponseGenerator() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(ResponseGenerator.class);
getResponseValue() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
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.
 
getReturnType() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getRollbacks() - Method in class org.infinispan.interceptors.TxInterceptor
 
getRoot() - Method in class org.infinispan.loaders.file.FileCacheStore
 
getRoot() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Returns the root of the current computation; i.e., this task if it has no completer, else its completer's root.
getRootElement() - Method in class org.infinispan.configuration.parsing.Namespace
 
getRoutingTableAsString() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns a string containing all the segments and their associated addresses.
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
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
 
getRunningThreadCount() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization.
getScheduledExecutor(Properties) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties) - Method in interface org.infinispan.executors.ScheduledExecutorFactory
 
getSegment(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getSegment(Object) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
getSegmentEndHashes() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getSegmentId() - Method in class org.infinispan.statetransfer.StateChunk
 
getSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
getSegments() - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
getSegmentsForOwner(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns the segments owned by a cache member.
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
getSegmentSize() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getSendTimeMillis() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getSendTimeMillis() - Method in interface org.infinispan.remoting.transport.BackupResponse
Return the time in millis when this operation was initiated.
getSendTimeMillis() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
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
 
getSiteName() - Method in class org.infinispan.xsite.XSiteBackup
 
getSiteNodes(String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getSiteRacks(String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getSocketBinding(String) - Method in class org.infinispan.configuration.as.ParserContextAS7
Searches for the named SocketBinding in all SocketBindingGroups
getSocketBinding(String) - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
getSocketBindingGroup(String) - Method in class org.infinispan.configuration.as.ParserContextAS7
 
getSortedMembers() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getSource() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
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
 
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);
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
 
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.
getStealCount() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns an estimate of the total number of tasks stolen from one thread's work queue by another.
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
 
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
 
getStrictPeerToPeer() - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
 
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.loaders.keymappers.MarshalledValueOrPrimitiveMapper
 
getSubElement(Element, String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Returns a named sub-element of the current element passed in.
getSubgroupsMerged() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getSubgroupsMerged() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.MergeEvent
 
getSuccessRatio() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuccessRatioFloatingPoint() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSupportedNamespaces() - Method in class org.infinispan.configuration.as.ParserAS7
 
getSupportedNamespaces() - Method in interface org.infinispan.configuration.parsing.ConfigurationParser
Returns an array of namespaces supported by this parser
getSupportedNamespaces() - Method in class org.infinispan.configuration.parsing.Parser51
 
getSupportedNamespaces() - Method in class org.infinispan.configuration.parsing.Parser52
 
getSurplusQueuedTaskCount() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns an estimate of how many more locally queued tasks are held by the current worker thread than there are other worker threads that might steal them, or zero if this thread is not operating in a ForkJoinPool.
getSuspect() - Method in exception org.infinispan.remoting.transport.jgroups.SuspectException
 
getSyncReplTimeout() - Method in class org.infinispan.config.Configuration
Deprecated.
 
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.
getTakeOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
getTakeOfflineAfterFailures(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
getTakeOfflineMinTimeToWait(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
getTaskExecutionPolicy() - Method in interface org.infinispan.distexec.DistributedTask
Returns custom DistributedTaskExecutionPolicy for this task
getTaskFailoverPolicy() - Method in interface org.infinispan.distexec.DistributedTask
Returns custom DistributedTaskFailoverPolicy for this task
getTaskId() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getTaskId() - Method in class org.infinispan.commands.read.ReduceCommand
 
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
 
getThrowable() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getTimeout() - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.
 
getTimeout() - Method in class org.infinispan.topology.CacheJoinInfo
 
getTimeout() - Method in class org.infinispan.xsite.XSiteBackup
 
getTimeSinceReset() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
 
getTimeSinceStart() - Method in class org.infinispan.stats.StatsImpl
 
getTopologyId() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
getTopologyId() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getTopologyId() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
getTopologyId() - Method in interface org.infinispan.commands.TopologyAffectedCommand
 
getTopologyId() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getTopologyId() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the current topology id.
getTopologyId() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTopologyId() - Method in class org.infinispan.statetransfer.TransactionInfo
 
getTopologyId() - Method in class org.infinispan.topology.CacheTopology
 
getTopologyId() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getTopologyId() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getTopologyId() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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
Number of entries stored in cache since the cache started running.
getTotalNumberOfEntries() - Method in class org.infinispan.stats.StatsImpl
 
getTotalReadLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getTotalSpace() - Method in class org.infinispan.io.GridFile
 
getTotalWriteLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
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.transaction.LocalTransaction
 
getTransaction() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Get the transaction associated with the calling thread.
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.
getTransactionsForSegments(Address, int, Set<Integer>) - Method in interface org.infinispan.statetransfer.StateProvider
Gets the list of transactions that affect keys from the given segments.
getTransactionsForSegments(Address, int, Set<Integer>) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
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() - 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.
 
getTransportNodeName() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
 
getTransportProperties() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
 
getTxStores() - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
getType() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
getType() - Method in class org.infinispan.factories.components.JmxOperationParameter
 
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.statetransfer.StateRequestCommand
 
getType() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
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.DeltaCompositeKey.DeltaCompositeKeyExternalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.RemoveOperation.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.DefaultConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.loaders.bucket.Bucket.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.CacheNotFoundResponse.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.StateChunk.Externalizer
 
getTypeClasses() - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheTopology.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.util.ByteArrayKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
getTypeClasses() - Method in class org.infinispan.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
getTypeClasses() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
getTypeClasses() - Method in class org.infinispan.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
getTypedProperties() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
getUncaughtExceptionHandler() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
getUncommitted(Object) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
getUncommittedChages() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getUnfinishedSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
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
 
getUri() - Method in class org.infinispan.configuration.parsing.Namespace
 
getUsableSpace() - Method in class org.infinispan.io.GridFile
 
getUse1PcForAutoCommitTransactions() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
 
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
 
getUUID() - Method in interface org.infinispan.commands.CancellableCommand
Returns UUID of a command
getUUID() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getUUID() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getUUID() - Method in class org.infinispan.commands.read.ReduceCommand
 
getValue() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getValue() - Method in class org.infinispan.commands.write.RemoveCommand
 
getValue() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder.FsyncModeEditor
Deprecated.
 
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() - 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
 
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() - 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
 
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.notifications.cachemanagerlistener.event.EventImpl
 
getViewId() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Get JGroups view id.
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getViewId() - Method in interface org.infinispan.remoting.transport.Transport
 
getWakeUpInterval() - Method in class org.infinispan.config.Configuration.EvictionType
getWakeUpInterval() - Method in class org.infinispan.config.Configuration.ExpirationType
Deprecated.
 
getWarningMessage(String, Location) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
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.
getWriteConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
 
getWriteConsistentHash() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getWriteConsistentHash() - Method in class org.infinispan.topology.CacheTopology
When there is a rebalance in progress, write operations should go to the "pending" members.
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.
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.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
 
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
 
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
GroupingConsistentHash - Class in org.infinispan.distribution.group
ConsistentHash wrapper that groups keys to the same node based on their @Group annotation.
GroupingConsistentHash(ConsistentHash, GroupManager) - Constructor for class org.infinispan.distribution.group.GroupingConsistentHash
 
GroupManager - Interface in org.infinispan.distribution.group
Control's key grouping.
GroupManagerFactory - Class in org.infinispan.distribution.group
 
GroupManagerFactory() - Constructor for class org.infinispan.distribution.group.GroupManagerFactory
 
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
 
handleClearFailure(String) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleClearFailure(String) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleCommitCommand(InvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleCommitFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleCommitFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleConsistentHashUpdate(String, CacheTopology, int) - Method in interface org.infinispan.topology.LocalTopologyManager
Updates the current and/or pending consistent hash, without transferring any state.
handleConsistentHashUpdate(String, CacheTopology, int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
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
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
handleEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleJoin(String, Address, CacheJoinInfo, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Updates the members list and notifies the RebalancePolicy.
handleJoin(String, Address, CacheJoinInfo, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleLeave(String, Address, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Updates the members list and notifies the RebalancePolicy
handleLeave(String, Address, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleLocalWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.NonTxConcurrentDistributionInterceptor
 
handleLocalWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
handleMarshallingException(Throwable, Object) - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
handleNewView(List<Address>, boolean, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handlePrepareCommand(InvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePrepareFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handlePrepareFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handlePutAllFailure(String, Map<K, V>) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handlePutAllFailure(String, Map<K, V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handlePutFailure(String, K, V, boolean) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handlePutFailure(String, K, V, boolean) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handlePutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handlePutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRebalance(String, CacheTopology, int) - Method in interface org.infinispan.topology.LocalTopologyManager
Performs the state transfer.
handleRebalance(String, CacheTopology, int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
handleRebalanceCompleted(String, Address, int, Throwable, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Marks the rebalance as complete on the sender.
handleRebalanceCompleted(String, Address, int, Throwable, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleRemoteCommand(VisitableCommand) - Method in interface org.infinispan.xsite.BackupReceiver
 
handleRemoteCommand(VisitableCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl
 
handleRemoteCommand(SingleRpcCommand, SiteAddress) - Method in interface org.infinispan.xsite.BackupReceiverRepository
Process an CacheRpcCommand received from a remote site.
handleRemoteCommand(SingleRpcCommand, SiteAddress) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
handleRemoteWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.NonTxConcurrentDistributionInterceptor
 
handleRemoteWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
handleRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRemoveFailure(String, K, V) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleRemoveFailure(String, K, V) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleReplaceFailure(String, K, V, V) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleReplaceFailure(String, K, V, V) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleRollbackCommand(InvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleRollbackFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleRollbackFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
 
handleStatusRequest(int) - Method in interface org.infinispan.topology.LocalTopologyManager
Recovers the current topology information for all running caches and returns it to the coordinator.
handleStatusRequest(int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
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.topology.ClusterTopologyManagerImpl.ClusterViewListener
 
handleWriteCommand(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
handleWriteCommand(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
handleWriteCommand(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
If we are within one transaction we won't do any replication as replication would only be performed at commit time.
handleWriteCommand(WriteCommand, Object) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
handleWriteCommand(WriteCommand, Object) - Method in class org.infinispan.remoting.responses.NoReturnValuesDistributionResponseGenerator
 
hasActiveTransfers() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
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.
 
hasEnabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
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
Deprecated.
 
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(Object) - Static method in class org.infinispan.util.AbstractMap
 
hashCode() - Method in class org.infinispan.atomic.DeltaCompositeKey
 
hashCode() - Method in class org.infinispan.atomic.PutOperation
 
hashCode() - Method in class org.infinispan.commands.CancelCommand
 
hashCode() - Method in class org.infinispan.commands.control.LockControlCommand
 
hashCode() - Method in class org.infinispan.commands.CreateCacheCommand
 
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.MapCombineCommand
 
hashCode() - Method in class org.infinispan.commands.read.ReduceCommand
 
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.AbstractLockSupportStoreConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AsyncConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
hashCode() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
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.LegacyLoaderConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.LegacyStoreConfiguration
 
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.SitesConfiguration
 
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.TakeOfflineConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
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.SiteConfiguration
 
hashCode() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.parsing.Namespace
 
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.mapreduce.MapReduceManagerImpl.IntermediateCompositeKey
 
hashCode() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
hashCode() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
hashCode() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
hashCode() - Method in class org.infinispan.io.GridFile
 
hashCode() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
 
hashCode() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
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.marshall.MarshalledValue
 
hashCode() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
hashCode() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
hashCode() - Method in class org.infinispan.remoting.MIMECacheEntry
 
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.AggregateBackupResponse
 
hashCode() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
hashCode() - Method in class org.infinispan.topology.CacheTopology
 
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.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.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
 
hashCode() - Method in class org.infinispan.util.ForwardingList
 
hashCode() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
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.
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.
hashNumVirtualNodesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
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
 
hasInUseBackup(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
hasJoiners() - Method in class org.infinispan.topology.ClusterCacheStatus
 
hasKeys() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
hasLocalOnlyModifications - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
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.SingleKeyNonTxInvocationContext
 
hasMembers() - Method in class org.infinispan.topology.ClusterCacheStatus
 
hasModification(Class<?>) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
hasModification(Class<?>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Checks if a modification of the given class (or subclass) is present in this transaction.
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
Checks if there are modifications performed within the tx's scope.
hasNext() - Method in class org.infinispan.container.DefaultDataContainer.EntryIterator
 
hasNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
hasNext() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
hasQueuedSubmissions() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasSkipLocking(FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
hasTopologyInfo() - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
 
hasTopologyInfo() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
hasUncommittedChanges() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
helpQuiesce() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.
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.
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
 
host() - Method in class org.infinispan.configuration.as.OutboundSocketBinding
 

I

icc - Variable in class org.infinispan.CacheImpl
 
icc - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
icc - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
icc - Variable in class org.infinispan.transaction.TransactionTable
 
id - Variable in class org.infinispan.config.AdvancedExternalizerConfig
 
id - Variable in class org.infinispan.transaction.xa.GlobalTransaction
 
Ids - Interface in org.infinispan.marshall
Indexes for object types.
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.remote.ClusteredGetCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
ignoreCommandOnStatus(ComponentStatus) - Method in interface org.infinispan.commands.VisitableCommand
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.AbstractStoreConfiguration
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.configuration.cache.AbstractStoreConfigurationBuilder
 
ignoreModifications(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
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.AbstractStoreConfigurationChildBuilder
 
ignoreModifications() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
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.configuration.cache.StoreConfigurationChildBuilder
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
 
ignorePreviousValueOnBackup(WriteCommand, InvocationContext) - Method in class org.infinispan.interceptors.ClusteringInterceptor
For conditional operations (replace, remove, put if absent) Used only for optimistic transactional caches, to solve the following situation:
ignorePreviousValueOnBackup(WriteCommand, InvocationContext) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
For conditional operations (replace, remove, put if absent) Used only for optimistic transactional caches, to solve the following situation:
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
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.
immutableTypedProperties(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
 
InboundTransferTask - Class in org.infinispan.statetransfer
Inbound state transfer task.
InboundTransferTask(Set<Integer>, Address, int, StateConsumerImpl, RpcManager, CommandsFactory, long, String) - Constructor for class org.infinispan.statetransfer.InboundTransferTask
 
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
 
incOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
incPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
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.
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_NS_BASE_URI - Static variable in class org.infinispan.configuration.parsing.Namespace
 
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.EmptyList - Class in org.infinispan.util
 
InfinispanCollections.EmptyList() - Constructor for class org.infinispan.util.InfinispanCollections.EmptyList
 
InfinispanCollections.EmptyList.EmptyListExternalizer - Class in org.infinispan.util
 
InfinispanCollections.EmptyList.EmptyListExternalizer() - Constructor for class org.infinispan.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
InfinispanCollections.EmptyMap - Class in org.infinispan.util
 
InfinispanCollections.EmptyMap() - Constructor for class org.infinispan.util.InfinispanCollections.EmptyMap
 
InfinispanCollections.EmptyMap.EmptyMapExternalizer - Class in org.infinispan.util
 
InfinispanCollections.EmptyMap.EmptyMapExternalizer() - Constructor for class org.infinispan.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
InfinispanCollections.EmptySet - Class in org.infinispan.util
 
InfinispanCollections.EmptySet() - Constructor for class org.infinispan.util.InfinispanCollections.EmptySet
 
InfinispanCollections.EmptySet.EmptySetExternalizer - Class in org.infinispan.util
 
InfinispanCollections.EmptySet.EmptySetExternalizer() - Constructor for class org.infinispan.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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 ParserRegistry instead
inForkJoinPool() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
init(CancellationService) - Method in class org.infinispan.commands.CancelCommand
 
init(EmbeddedCacheManager) - Method in class org.infinispan.commands.CreateCacheCommand
 
init(Cache<Object, Object>) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
init(MapReduceManager) - Method in class org.infinispan.commands.read.MapCombineCommand
 
init(MapReduceManager) - Method in class org.infinispan.commands.read.ReduceCommand
 
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, StateTransferManager) - 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<?, ?>) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
init(TransactionManager, TransactionTable, Configuration) - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
init(EmbeddedCacheManager, CacheLoaderManager, ExecutorService) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
init(RpcManager, StateTransferManager) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
init(Configuration, RpcManager, CommandsFactory, ExecutorService, ScheduledExecutorService) - Method in class org.infinispan.distribution.L1ManagerImpl
 
init() - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
init(CacheLoaderManager, InternalEntryFactory, TransactionManager) - Method in class org.infinispan.interceptors.CacheStoreInterceptor
 
init(L1Manager, ClusteringDependentLogic, LockManager, EntryFactory, CommandsFactory) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
init(L1Manager) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
init(EntryFactory, DataContainer, ClusteringDependentLogic, CommandsFactory, StateConsumer, StateTransferLock) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
init(TransactionManager, ComponentRegistry, TransactionTable, InvocationContextContainer) - Method in class org.infinispan.interceptors.InvocationContextInterceptor
 
init(DataContainer, CacheNotifier, Configuration) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
init(DistributionManager, Configuration, RpcManager, StateTransferLock) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
init(RpcManager, StateTransferManager) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
init(StateTransferLock) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
init(CommandsFactory) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
init(TransactionTable, Configuration, TransactionCoordinator, RpcManager, RecoveryManager) - 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 interface org.infinispan.loaders.CacheLoader
Used to initialize a cache loader.
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.LockSupportCacheStore
 
init(Cache, ExecutorService, StateTransferManager, InterceptorChain, InvocationContextContainer, Configuration, RpcManager, TransactionManager, CommandsFactory, CacheLoaderManager, DataContainer, TransactionTable, StateTransferLock, CacheNotifier) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
init(Cache, ExecutorService, Configuration, RpcManager, CommandsFactory, CacheNotifier, CacheLoaderManager, DataContainer, TransactionTable, StateTransferLock, StateConsumer) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
init(StateProvider) - Method in class org.infinispan.statetransfer.StateRequestCommand
 
init(StateConsumer) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
init(StateTransferLock, Configuration, CommandsFactory, StateTransferManager) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
init(StateConsumer, StateProvider, Cache, CacheNotifier, Configuration, GlobalConfiguration, RpcManager, GroupManager, LocalTopologyManager) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
init(LocalTopologyManager, ClusterTopologyManager, RebalancePolicy) - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
init(Configuration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
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, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
init(RecoveryManager, Cache) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
init() - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
init(Cache) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
init(Cache, Transport, TransactionTable, GlobalConfiguration) - Method in class org.infinispan.xsite.BackupSenderImpl
 
init(Cache<K, V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
Invoked during the initialization phase.
init(BackupSender) - Method in class org.infinispan.xsite.XSiteAdminCommand
 
init(RpcManager, BackupSender, Cache) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
initCache(String, ClusterCacheStatus) - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
initCache(String, ClusterCacheStatus) - Method in interface org.infinispan.topology.RebalancePolicy
Initialize the policy for a cache, without a list of members.
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(EvictionManager, PassivationManager, InternalEntryFactory, ActivationManager, CacheLoaderManager) - Method in class org.infinispan.container.DefaultDataContainer
 
initialize(ScheduledExecutorService, Cache, Configuration, DataContainer, CacheLoaderManager, CacheNotifier) - Method in class org.infinispan.eviction.EvictionManagerImpl
 
initialize(Iterable<ModuleMetadataFileFinder>, ClassLoader) - 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(StreamingMarshaller, ExecutorService, InboundInvocationHandler, CacheManagerNotifier, GlobalComponentRegistry, BackupReceiverRepository) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
Initializes the transport with global cache configuration and transport-specific properties.
initialize(RpcManager, Configuration, InvocationContextContainer, InterceptorChain, CacheNotifier, TransactionFactory, TransactionCoordinator, TransactionSynchronizationRegistry, CommandsFactory, ClusteringDependentLogic, Cache) - Method in class org.infinispan.transaction.TransactionTable
 
initialize(RecoveryManager) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
initialize(Cache<Object, Object>) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
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.
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
 
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, Configuration) - Method in class org.infinispan.eviction.ActivationManagerImpl
 
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(GlobalConfiguration) - Method in class org.infinispan.factories.TestDelayFactory
 
inject(Configuration, ActivationManager) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
inject(RpcManager) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
inject(CacheNotifier) - Method in class org.infinispan.interceptors.CallInterceptor
 
inject(DistributionManager, Transport, ClusteringDependentLogic) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
inject(AdvancedCache<Object, Object>, StreamingMarshaller, Configuration, InvocationContextContainer, TransactionManager) - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
inject(Cache, Configuration, InvocationContextContainer, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.CacheMarshaller
 
inject(ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.GlobalMarshaller
 
inject(RemoteCommandsFactory, GlobalComponentRegistry, StreamingMarshaller) - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
inject(Cache, Configuration, InvocationContextContainer, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
inject(GlobalComponentRegistry, Transport, GlobalConfiguration, CancellationService) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
inject(DistributionManager) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
inject(Transport, RebalancePolicy, ExecutorService, GlobalConfiguration, GlobalComponentRegistry, CacheManagerNotifier) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
inject(ClusterTopologyManager) - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
inject(Transport, ExecutorService, GlobalComponentRegistry) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
injectCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
injectConfiguration(Configuration) - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
injectDependencies(EvictionManager, InvocationContextContainer, CommandsFactory, InterceptorChain, Configuration, CacheNotifier, ComponentRegistry, TransactionManager, BatchContainer, RpcManager, DataContainer, StreamingMarshaller, ResponseGenerator, DistributionManager, EmbeddedCacheManager, ExecutorService, TransactionTable, RecoveryManager, TransactionCoordinator, LockManager, GlobalConfiguration) - 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(CommandsFactory, EntryFactory, LockManager, DataContainer, StateTransferManager) - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
injectDependencies(DistributionManager, ClusteringDependentLogic) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
injectDependencies(CommandsFactory) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
injectDependencies(CacheNotifier) - Method in class org.infinispan.interceptors.NotificationInterceptor
 
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, Cache, Configuration, GlobalConfiguration, ReplicationQueue, CommandsFactory, ExecutorService, LocalTopologyManager, StateTransferManager) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
injectDependencies(Configuration, LockContainer<?>) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
injectFactoryForComponent(Class<?>, Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Inject a factory for a given component type.
injectMarshaller(StreamingMarshaller, DistributionManager) - Method in class org.infinispan.interceptors.IsMarshallableInterceptor
 
injectMarshaller(StreamingMarshaller, InternalEntryFactory) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
inputKeys() - Method in interface org.infinispan.distexec.FailoverContext
Returns a list of input keys for this task.
inputTaskKeysEmpty() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
insertBucket(Bucket) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
Inserts a new Bucket in the storage system.
INSTANCE - Static variable in class org.infinispan.context.impl.ImmutableContext
 
instance - Variable in class org.infinispan.marshall.MarshalledValue
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.CacheNotFoundResponse
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsureResponse
 
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(ComponentMetadataRepo) - Constructor for class org.infinispan.interceptors.InterceptorChain
Constructs an interceptor chain having the supplied interceptor as first.
InterceptorChainFactory - Class in org.infinispan.factories
Factory class that builds an interceptor chain based on cache configuration.
InterceptorChainFactory() - Constructor for class org.infinispan.factories.InterceptorChainFactory
 
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.
interceptors(List<InterceptorConfiguration>) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
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.
invalidate(InvocationContext, Object) - Method in class org.infinispan.commands.write.InvalidateCommand
 
invalidateAcrossCluster(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, Set<Flag>, Object...) - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateCommand(CacheNotifier, Set<Flag>, Collection<Object>) - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateL1Command - Class in org.infinispan.commands.write
Invalidates an entry in a L1 cache (used with DIST mode)
InvalidateL1Command() - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(boolean, DataContainer, Configuration, DistributionManager, CacheNotifier, Set<Flag>, Object...) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(boolean, DataContainer, Configuration, DistributionManager, CacheNotifier, Set<Flag>, Collection<Object>) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(Address, boolean, DataContainer, Configuration, DistributionManager, CacheNotifier, Set<Flag>, Collection<Object>) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidationInterceptor - Class in org.infinispan.interceptors
This interceptor acts as a replacement to the replication interceptor when the CacheImpl is configured with ClusteredSyncMode as INVALIDATE.
InvalidationInterceptor() - Constructor for class org.infinispan.interceptors.InvalidationInterceptor
 
InvalidationInterceptor.InvalidationFilterVisitor - Class in org.infinispan.interceptors
 
InvalidationInterceptor.InvalidationFilterVisitor(int) - Constructor for class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
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.
InvalidCacheUsageException - Exception in org.infinispan
Thrown when client makes cache usage errors.
InvalidCacheUsageException(Throwable) - Constructor for exception org.infinispan.InvalidCacheUsageException
 
InvalidCacheUsageException(String) - Constructor for exception org.infinispan.InvalidCacheUsageException
 
InvalidCacheUsageException(String, Throwable) - Constructor for exception org.infinispan.InvalidCacheUsageException
 
invalidManagedAttributeMethod(String) - Method in interface org.infinispan.util.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.
InvalidResponse - Class in org.infinispan.remoting.responses
An invalid response
InvalidResponse() - Constructor for class org.infinispan.remoting.responses.InvalidResponse
 
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.
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
 
invoke(ForkJoinTask<T>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Performs the given task, returning its result upon completion.
invoke() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Commences performing this task, awaits its completion if necessary, and returns its result, or throws an (unchecked) RuntimeException or Error if the underlying computation did so.
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
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(ForkJoinTask<?>...) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(Collection<T>) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Forks all tasks in the specified collection, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
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
 
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.
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, 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
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
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
 
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
 
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
 
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
 
isAsyncBackup() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isAsyncMarshalling() - Method in class org.infinispan.config.Configuration.AsyncType
Deprecated.
 
isBackupFor(String, String) - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
isBalanced(ConsistentHash) - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
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.statetransfer.OutboundTransferTask
 
isCancelled() - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
 
isCancelled() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
isCancelled() - Method in class org.infinispan.util.concurrent.NotifyingFutureAdaptor
 
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
isClustered() - Method in enum org.infinispan.config.Configuration.CacheMode
Deprecated.
 
isClustered() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isCommitOrRollbackSent() - Method in class org.infinispan.transaction.LocalTransaction
 
isCompletedAbnormally() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedNormally() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns true if this task completed without throwing an exception and was not cancelled.
isCompletionFailed() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
Returns true if this transaction failed during 2nd phase of 2PC(prepare or commit).
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.
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
 
isCustomConsistentHashClass() - Method in class org.infinispan.config.Configuration
Deprecated.
No longer useful, since Configuration.getConsistentHashClass() is not used.
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.
isDeltaWrite(Set<Flag>) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
Indicates whether the operation is a delta write.
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
 
isDone() - Method in class org.infinispan.util.concurrent.AbstractInProcessFuture
 
isDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
isDone() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
isDone() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
 
isDone() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
isDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureAdaptor
 
isDone() - Method in class org.infinispan.util.concurrent.NotifyingFutureImpl
 
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.
 
isEmitCompositeIntermediateKeys() - Method in class org.infinispan.commands.read.MapCombineCommand
 
isEmitCompositeIntermediateKeys() - Method in class org.infinispan.commands.read.ReduceCommand
 
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.DecoratedCache
 
isEmpty() - Method in class org.infinispan.loaders.bucket.Bucket
 
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.InfinispanCollections.EmptyMap
 
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
 
isEnabled() - Method in class org.infinispan.xsite.OfflineStatus
 
isEnableDeadlockDetection() - Method in class org.infinispan.config.Configuration
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
 
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.
isForwarded() - Method in class org.infinispan.commands.write.PutMapCommand
For non transactional caches that support concurrent writes (default), the commands are forwarded between nodes, e.g.: - commands is executed on node A, but some of the keys should be locked on node B - the command is send to the main owner (B) - B tries to acquire lock on the keys it owns, then forwards the commands to the other owners as well - at this last stage, the command has the "isForwarded" flag set to true.
isFromRemoteSite() - Method in class org.infinispan.transaction.LocalTransaction
When x-site replication is used, this returns when this operation happens as a result of backing up data from a remote site.
isFromStateTransfer(InvocationContext) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
isFromStateTransfer(FlagAffectedCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
isFromStateTransfer() - Method in class org.infinispan.transaction.LocalTransaction
 
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
 
isHidden() - Method in class org.infinispan.io.GridFile
 
isIBMJavaVendor() - Static method in class org.infinispan.util.Util
 
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
 
isIgnorePreviousValue() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
isIgnorePreviousValue() - Method in class org.infinispan.commands.write.ClearCommand
 
isIgnorePreviousValue() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isIgnorePreviousValue() - Method in class org.infinispan.commands.write.PutMapCommand
 
isIgnorePreviousValue() - Method in class org.infinispan.commands.write.RemoveCommand
 
isIgnorePreviousValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
isIgnorePreviousValue() - Method in interface org.infinispan.commands.write.WriteCommand
Only relevant for conditional commands.
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.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.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
 
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 interface org.infinispan.statetransfer.StateTransferManager
 
isJoinComplete() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
isKeyGeneratorThreadActive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isKeyGeneratorThreadAlive() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isKeyLocalToNode(Address, Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Test to see whether a key is owned by a given node.
isKeyLocalToNode(Address, Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
isKeyLocalToNode(Address, Object) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
isKeyLocalToNode(Address, Object) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
isKeyUpdated(Object) - Method in interface org.infinispan.statetransfer.StateConsumer
Checks if a given key was updated by user code during state transfer (and consequently it is untouchable by state transfer).
isKeyUpdated(Object) - Method in class org.infinispan.statetransfer.StateConsumerImpl
Checks if a given key was updated by user code during state transfer (and consequently it is untouchable by state transfer).
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
 
isLastChunk() - Method in class org.infinispan.statetransfer.StateChunk
 
isLoaded() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isLoaded() - Method in interface org.infinispan.container.entries.CacheEntry
 
isLoaded() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isLoaded() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
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(FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
isLocatedLocally(String) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
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
 
isMarkedForRollback() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
isMarkedForRollback() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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
 
isMergeView() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
isMergeView() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
isMissingLookedUpEntries() - 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
isNeedReliableReturnValues(FlagAffectedCommand) - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
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
 
isOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
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.
 
isOnePhaseCommit(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
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.AbstractInvocationContext
 
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.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.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
 
IspnMBeanOperationInfo - Class in org.infinispan.jmx
Infinispan allows a different JMX operation name than the actual method name that gets invoked (see ManagedOperation.name().
IspnMBeanOperationInfo(String, Method, String) - Constructor for class org.infinispan.jmx.IspnMBeanOperationInfo
 
IspnMBeanOperationInfo(String, String, MBeanParameterInfo[], String, int, String) - Constructor for class org.infinispan.jmx.IspnMBeanOperationInfo
 
IspnMBeanOperationInfo(String, String, MBeanParameterInfo[], String, int, Descriptor, String) - Constructor for class org.infinispan.jmx.IspnMBeanOperationInfo
 
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
 
isPrepareSent() - Method in class org.infinispan.transaction.LocalTransaction
 
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
 
isQuiescent() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns true if all worker threads are currently idle.
isReadOnly() - Method in class org.infinispan.transaction.LocalTransaction
 
isRebalanceInProgress() - Method in class org.infinispan.topology.ClusterCacheStatus
 
isRebalancingEnabled() - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
isRebalancingEnabled() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
isRebalancingEnabled() - Method in interface org.infinispan.topology.RebalancePolicy
 
isRecoveryEnabled() - Method in enum org.infinispan.configuration.as.TransactionMode
 
isReducePhaseDistributed() - Method in class org.infinispan.commands.read.MapCombineCommand
 
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
isReleasable() - Method in interface org.infinispan.util.concurrent.jdk8backported.ForkJoinPool.ManagedBlocker
Returns true if blocking is unnecessary.
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.CancelCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.CreateCacheCommand
 
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.MapCombineCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.read.ReduceCommand
 
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.recovery.TxCompletionNotificationCommand
 
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.statetransfer.StateRequestCommand
 
isReturnValueExpected() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
isReturnValueExpected() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
isReturnValueExpected() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
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.
isSecondPhaseAsync(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isShared() - Method in class org.infinispan.config.CacheLoaderManagerConfig
 
isShared() - Method in interface org.infinispan.loaders.CacheLoaderManager
 
isShared() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
isShutdown - 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.jdk8backported.ForkJoinPool
Returns true if this pool has been shut down.
isShutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isSingleOwnerAndLocal(BaseDistributionInterceptor.RecipientGenerator) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
If a single owner has been configured and the target for the key is the local address, it returns 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
 
isStateTransferEnabled() - Method in class org.infinispan.config.Configuration
Deprecated.
 
isStateTransferEnabled(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateConsumer
 
isStateTransferInProgress() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateProvider
 
isStateTransferInProgress() - Method in class org.infinispan.statetransfer.StateProviderImpl
 
isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateTransferManager
Checks if an inbound state transfer is in progress.
isStateTransferInProgress() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
isStateTransferInProgressForKey(Object) - Method in interface org.infinispan.statetransfer.StateConsumer
 
isStateTransferInProgressForKey(Object) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
isStateTransferInProgressForKey(Object) - Method in interface org.infinispan.statetransfer.StateTransferManager
Checks if an inbound state transfer is in progress for a given key.
isStateTransferInProgressForKey(Object) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
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
 
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.loaders.keymappers.MarshalledValueOrPrimitiveMapper
 
isSurvivesRestarts() - Method in class org.infinispan.factories.components.ComponentMetadata
 
isSuspendTxAfterInvocation() - Method in class org.infinispan.batch.BatchContainer
 
isSync() - Method in class org.infinispan.xsite.XSiteBackup
 
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.
 
isSyncCommitPhase() - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
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.as.Mode
 
isSynchronous() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isSynchronous(FlagAffectedCommand) - 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.
 
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.jdk8backported.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isTerminating() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Returns true if the process of termination has commenced but not yet completed.
isTransactional() - Method in enum org.infinispan.transaction.TransactionMode
 
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.
isTransactionCompleted(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
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
 
isTwoPhaseCommit() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
isTxFromRemoteSite(GlobalTransaction) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
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.
 
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.
 
isUseEagerLocking() - Method in class org.infinispan.config.Configuration
Deprecated.
isUseEagerLocking() - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
 
isUseLazyDeserialization() - Method in class org.infinispan.config.Configuration
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
 
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
 
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.
 
isXAEnabled() - Method in enum org.infinispan.configuration.as.TransactionMode
 
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() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
iterator() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
 
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.InfinispanCollections.EmptyList
 
iterator() - Method in class org.infinispan.util.InfinispanCollections.EmptySet
 
iterator() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 

J

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(ExternalizerTable, Configuration, InvocationContextContainer, GlobalConfiguration) - 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
 
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
 
JGroupsBackupResponse - Class in org.infinispan.remoting.transport.jgroups
 
JGroupsBackupResponse(Map<XSiteBackup, Future<Object>>) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
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
 
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
 
JmxOperationMetadata - Class in org.infinispan.factories.components
Persistable and cacheable metadata for JMX operations
JmxOperationMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxOperationMetadata
 
JmxOperationParameter - Class in org.infinispan.factories.components
JmxOperationParameter stores metadata information about MBean operation parameters which is then used at runtime to build the relevant MBeanParameterInfo
JmxOperationParameter(String, String, String) - Constructor for class org.infinispan.factories.components.JmxOperationParameter
 
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, CacheJoinInfo, CacheTopologyHandler) - Method in interface org.infinispan.topology.LocalTopologyManager
Forwards the join request to the coordinator.
join(String, CacheJoinInfo, CacheTopologyHandler) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
join() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns the result of the computation when it is done.
joinRehashAborted(Address, String) - Method in interface org.infinispan.util.logging.Log
 
joinRehashCompleted(Address, String) - Method in interface org.infinispan.util.logging.Log
 

K

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
 
Key2StringMapper - Interface in org.infinispan.loaders.keymappers
Defines the logic of mapping a key object to a String.
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
 
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.write.InvalidateCommand
 
keys - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
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 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(V) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a Set view of the keys in this map, using the given common mapped value for any additions (i.e., Collection.add(E) and Collection.addAll(Collection)).
keySet() - Method in class org.infinispan.util.FastCopyHashMap
 
keySet() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
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
 
keysToExecutionNodes(DistributedTaskExecutionPolicy, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
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
 
L1NonTxInterceptor - Class in org.infinispan.interceptors.distribution
Interceptor that handles L1 logic for non-transactional caches.
L1NonTxInterceptor() - Constructor for class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
l1OnRehash(boolean) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
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
 
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
 
leave(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Forwards the leave request to the coordinator.
leave(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
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
 
LegacyLoaderAdapter<T extends CacheLoaderConfig> - Interface in org.infinispan.configuration.cache
Deprecated.
LegacyLoaderConfiguration - Class in org.infinispan.configuration.cache
Configuration a legacy cache loader or cache store, i.e.
LegacyLoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration a legacy cache loader, i.e.
LegacyLoaderConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
 
LegacyStoreConfiguration - Class in org.infinispan.configuration.cache
Configuration a legacy cache store, i.e.
LegacyStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration of a legacy cache store, i.e.
LegacyStoreConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
 
length() - Method in class org.infinispan.io.GridFile
 
Lifecycle - Interface in org.infinispan.lifecycle
Lifecycle interface that defines the lifecycle of components
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(long, TimeUnit) - 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(long, TimeUnit) - 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
 
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
 
load(Object) - Method in interface org.infinispan.loaders.CacheLoader
Loads an entry mapped to by a given key.
load(int) - Method in interface org.infinispan.loaders.CacheLoader
Loads up to a specific number of entries.
load(Object) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(int) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
load(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(int) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
load(Object) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
load(int) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
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.LockSupportCacheStore
 
load(int) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAll() - Method in interface org.infinispan.loaders.CacheLoader
Loads all entries in the loader.
loadAll() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAll() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAll() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
loadAll() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAll() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllKeys(Set<Object>) - Method in interface org.infinispan.loaders.CacheLoader
Loads a set of all keys, excluding a filter set.
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
loadAllKeys(Set<Object>) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllKeysFromCacheLoaderUsingFilter(Set<KIn>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadAllKeysLockSafe(Set<Object>) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.bucket.BucketBasedCacheStore
 
loadAllLockSafe() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
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.file.FileCacheStore
 
loadBucket(File) - Method in class org.infinispan.loaders.file.FileCacheStore
 
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 legacy cache store, i.e.
LoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration of a legacy cache store, i.e.
LoaderConfigurationBuilder(LoadersConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.LoaderConfigurationBuilder
 
LoaderConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
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.LockSupportCacheStore
 
loadLockSafe(Object, L) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
loadModuleCommandHandlers(ClassLoader) - Method in class org.infinispan.util.ModuleProperties
 
loadValueFromCacheLoader(KIn) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
LOCAL_MODE_ADDRESS - Static variable in class org.infinispan.distexec.DefaultExecutorService
 
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
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in interface org.infinispan.util.logging.Log
 
localLockIntention - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
localModeWriteSkewCheck - Variable in class org.infinispan.container.EntryFactoryImpl
 
localNodeIsOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
localNodeIsOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
localNodeIsOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
localNodeIsOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
localNodeIsPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
localNodeIsPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
localNodeIsPrimaryOwner(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
localNodeIsPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
localSite() - Method in class org.infinispan.configuration.global.SiteConfiguration
Returns the name of the local site.
localSite(String) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
Sets the name of the local site.
LocalTopologyManager - Interface in org.infinispan.topology
Runs on every node and handles the communication with the ClusterTopologyManager.
LocalTopologyManagerFactory - Class in org.infinispan.topology
Factory for ClusterTopologyManager implementations
LocalTopologyManagerFactory() - Constructor for class org.infinispan.topology.LocalTopologyManagerFactory
 
LocalTopologyManagerImpl - Class in org.infinispan.topology
The LocalTopologyManager implementation.
LocalTopologyManagerImpl() - Constructor for class org.infinispan.topology.LocalTopologyManagerImpl
 
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) - 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>) - Method in interface org.infinispan.distribution.DistributionManager
Locates a list of keys in a cluster.
locateAll(Collection<Object>) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateAllOwners(Collection<Object>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
The logical equivalent of calling ConsistentHash.locateOwners(java.lang.Object) multiple times for each key in the collection of keys and merging the results.
locateAllOwners(Collection<Object>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
locateAllOwners(Collection<Object>) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
locateAllOwners(Collection<Object>) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
locateKey(String) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
locateOwners(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Finds all the owners of a key.
locateOwners(Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
locateOwners(Object) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
locateOwners(Object) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
locateOwnersForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
locatePrimaryOwner(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Should be equivalent to return the first element of ConsistentHash.locateOwners(java.lang.Object).
locatePrimaryOwner(Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
locatePrimaryOwner(Object) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
locatePrimaryOwner(Object) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
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(Object, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
lock(L, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
 
lock(OwnableRefCountingReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantPerEntryLockContainer
 
lock(OwnableReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
lock(VisibleOwnerRefCountingReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
lock(VisibleOwnerReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
lock() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
lock(Object) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
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
lockAcquisitionTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Maximum time to attempt a particular lock acquisition
lockAcquistionTimeout() - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfiguration
 
lockAcquistionTimeout - Variable in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationBuilder
 
lockAcquistionTimeout(long) - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationBuilder
 
lockAcquistionTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationBuilder
 
lockAcquistionTimeout(long) - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationChildBuilder
 
lockAcquistionTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationChildBuilder
 
lockAcquistionTimeout() - Method in interface org.infinispan.configuration.cache.LockSupportStoreConfiguration
The timeout in milliseconds before giving up on acquiring a lock
lockAcquistionTimeout(long) - Method in interface org.infinispan.configuration.cache.LockSupportStoreConfigurationChildBuilder
 
lockAcquistionTimeout(long, TimeUnit) - Method in interface org.infinispan.configuration.cache.LockSupportStoreConfigurationChildBuilder
 
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, long, boolean) - 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, long, boolean) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
lockConcurrencyLevel() - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfiguration
 
lockConcurrencyLevel - Variable in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationBuilder
 
lockConcurrencyLevel(int) - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationBuilder
 
lockConcurrencyLevel(int) - Method in class org.infinispan.configuration.cache.AbstractLockSupportStoreConfigurationChildBuilder
 
lockConcurrencyLevel() - Method in interface org.infinispan.configuration.cache.LockSupportStoreConfiguration
This value determines the number of threads that can concurrently access the lock container
lockConcurrencyLevel(int) - Method in interface org.infinispan.configuration.cache.LockSupportStoreConfigurationChildBuilder
 
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
Holds all the keys that were actually locked on the local node.
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.
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.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, long, boolean) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
lockKeyAndCheckOwnership(InvocationContext, Object, long, boolean) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
Besides acquiring a lock, this method also handles the following situation: 1.
lockManager - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
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
 
LockSupportStoreConfiguration - Interface in org.infinispan.configuration.cache
LockSupportStoreConfiguration.
LockSupportStoreConfigurationBuilder<T extends LockSupportStoreConfiguration,S extends LockSupportStoreConfigurationBuilder<T,S>> - Interface in org.infinispan.configuration.cache
LockSupportCacheStoreConfigurationBuilder is an interface which should be implemented by all cache store builders which support locking
LockSupportStoreConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
LockSupportCacheStoreConfigurationBuilder is an interface which should be implemented by all cache store builders which support locking
log - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
log - Static variable in class org.infinispan.transaction.tm.DummyTransactionManager
 
Log - Interface in org.infinispan.util.logging
Infinispan's log abstraction layer on top of JBoss Logging.
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
 
logRoutingTableInformation() - Method in class org.infinispan.topology.CacheTopology
 
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.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, 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 : FileLookupFactory.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 : FileLookupFactory.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.file.FileCacheStore
 

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.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.factories.components.ComponentMetadataPersister
Usage: ComponentMetadataPersister [path containing .class files to scan] [output file to generate]
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
 
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
 
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.
managedBlock(ForkJoinPool.ManagedBlocker) - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Blocks in accord with the given blocker.
ManagedOperation - Annotation Type in org.infinispan.jmx.annotations
Indicates that a method in an MBean class defines an MBean operation.
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(MapCombineCommand<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
map - Variable in class org.infinispan.util.concurrent.ConcurrentHashSet
 
mapAndCombineForDistributedReduction(MapCombineCommand<KIn, VIn, KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.MapReduceManager
Invoked when MapCombineCommand arrives to a target Infinispan node and returns set of intermediate keys that needs to be reduced.
mapAndCombineForDistributedReduction(MapCombineCommand<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
mapAndCombineForLocalReduction(MapCombineCommand<KIn, VIn, KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.MapReduceManager
Invoked when MapCombineCommand arrives to a target Infinispan node and returns map of resulting values that need to be reduced.
mapAndCombineForLocalReduction(MapCombineCommand<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
MapCombineCommand<KIn,VIn,KOut,VOut> - Class in org.infinispan.commands.read
MapCombineCommand is a container to migrate Mapper and Reducer which is a combiner to a remote Infinispan node where it will get executed and return the result to an invoking/master node.
MapCombineCommand() - Constructor for class org.infinispan.commands.read.MapCombineCommand
 
MapCombineCommand(String) - Constructor for class org.infinispan.commands.read.MapCombineCommand
 
MapCombineCommand(String, Mapper<KIn, VIn, KOut, VOut>, Reducer<KOut, VOut>, String, Collection<KIn>) - Constructor for class org.infinispan.commands.read.MapCombineCommand
 
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(DistributionManager, String, Collection<T>, boolean) - Method in interface org.infinispan.distexec.mapreduce.MapReduceManager
Maps Map/Reduce task intermediate or input keys to nodes on Infinispan cluster
mapKeysToNodes(DistributionManager, String, Collection<T>, boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
mapKeysToNodes(DistributionManager, Collection<T>, boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
mapKeysToNodes(Collection<T>, boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
mapKeysToNodes(Collection<T>) - 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.
mapper - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
mappingCount() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the number of mappings.
MapReduceManager - Interface in org.infinispan.distexec.mapreduce
MapReduceManager is an internal Infinispan component receiving map/reduce invocations arriving from remote Infinispan nodes.
mapReduceManager - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
MapReduceManagerFactory - Class in org.infinispan.distexec.mapreduce
MapReduceManagerFactory is a default factory class for MapReduceManager.
MapReduceManagerFactory() - Constructor for class org.infinispan.distexec.mapreduce.MapReduceManagerFactory
 
MapReduceManagerImpl - Class in org.infinispan.distexec.mapreduce
Default implementation of MapReduceManager.
MapReduceManagerImpl.IntermediateCompositeKey<V> - Class in org.infinispan.distexec.mapreduce
IntermediateCompositeKey
MapReduceManagerImpl.IntermediateCompositeKey(String, V) - Constructor for class org.infinispan.distexec.mapreduce.MapReduceManagerImpl.IntermediateCompositeKey
 
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.
MapReduceTask(Cache<KIn, VIn>, boolean) - Constructor for class org.infinispan.distexec.mapreduce.MapReduceTask
Create a new MapReduceTask given a master cache node.
MapReduceTask(Cache<KIn, VIn>, boolean, boolean) - Constructor for class org.infinispan.distexec.mapreduce.MapReduceTask
Create a new MapReduceTask given a master cache node.
MapReduceTaskLifecycle - Interface in org.infinispan.distexec.mapreduce.spi
 
MapReduceTaskLifecycleService - Class in org.infinispan.distexec.mapreduce.spi
 
MAPS - Static variable in interface org.infinispan.marshall.Ids
 
markCommitOrRollbackSent() - Method in class org.infinispan.transaction.LocalTransaction
Sets the commit or rollback sent for this transaction
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.AbstractCacheTransaction
 
markForRollback(boolean) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
markMarshallable(Class<?>, boolean) - Method in class org.infinispan.marshall.MarshallableTypeHints
Marks a particular type as being marshallable or not being not marshallable.
markPrepareSent() - Method in class org.infinispan.transaction.LocalTransaction
Sets the prepare sent for this transaction
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
 
markTransactionCompleted(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
With the current state transfer implementation it is possible for a transaction to be prepared several times on a remote node.
marshal(Configuration.ClusteringType) - Method in class org.infinispan.config.Configuration.ClusteringTypeAdapter
Deprecated.
 
marshal(TypedProperties) - Method in class org.infinispan.config.TypedPropertiesAdapter
 
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
 
MarshalledValueOrPrimitiveMapper - Class in org.infinispan.loaders.keymappers
This class is an implementation for TwoWayKey2StringMapper that supports both primitives and MarshalledValues.
MarshalledValueOrPrimitiveMapper() - Constructor for class org.infinispan.loaders.keymappers.MarshalledValueOrPrimitiveMapper
 
marshaller - Variable in class org.infinispan.CacheImpl
 
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.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
 
MarshallingTwoWayKey2StringMapper - Interface in org.infinispan.loaders.keymappers
MarshallingTwoWayKey2StringMapper.
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_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.
maxFailoverAttempts() - Method in interface org.infinispan.distexec.DistributedTaskFailoverPolicy
Maximum number of fail over attempts permitted by this DistributedTaskFailoverPolicy
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(long, TimeUnit) - 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
 
MBean - Annotation Type in org.infinispan.jmx.annotations
Classes annotated with this will be exposed as MBeans.
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
 
MeasurementType - Enum in org.infinispan.jmx.annotations
 
members - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
MembershipArithmetic - Class in org.infinispan.remoting
A helper to perform common arithmetic functions with membership lists
MembershipArithmetic() - Constructor for class org.infinispan.remoting.MembershipArithmetic
 
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
 
merge(K, V, ConcurrentHashMapV8.BiFun<? super V, ? super V, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
If the specified key is not already associated with a (non-null) value, associates it with the given value.
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.
metadata - Variable in class org.infinispan.io.GridFilesystem
 
method - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
millisSinceFirstFailure() - Method in class org.infinispan.xsite.OfflineStatus
 
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
 
minTimeHasElapsed() - Method in class org.infinispan.xsite.OfflineStatus
 
minTimeToWait() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
minTimeToWait(long) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
The minimal number of millis to wait before taking this site offline, even in the case 'afterFailures' is reached.
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.
Mode - Enum in org.infinispan.configuration.as
 
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.AsyncStoreConfiguration
Sets the size of the modification queue for the async store.
modificationQueueSize(int) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
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
 
module(Class<T>) - Method in class org.infinispan.configuration.cache.Configuration
 
module(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
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.
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
 
modules() - Method in class org.infinispan.configuration.cache.Configuration
 
modules() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
modules() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
modules() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
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
 
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() - Method in class org.infinispan.configuration.as.NetworkInterface
 
name() - Method in class org.infinispan.configuration.as.OutboundSocketBinding
 
name() - Method in class org.infinispan.configuration.as.SocketBinding
 
name() - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
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
 
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 - Class in org.infinispan.configuration.parsing
Namespace.
Namespace(String) - Constructor for class org.infinispan.configuration.parsing.Namespace
 
Namespace(String, String, int, int) - Constructor for class org.infinispan.configuration.parsing.Namespace
 
Namespace(String, String, String, int, int) - Constructor for class org.infinispan.configuration.parsing.Namespace
 
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
 
needConsistentHashUpdate() - Method in class org.infinispan.topology.ClusterCacheStatus
 
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
 
needReliableReturnValues - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
needsRemoteGet(InvocationContext, AbstractDataCommand) - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
needToDestroyFailedCache() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
needToInitializeBeforeStart() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
NetworkInterface - Class in org.infinispan.configuration.as
NetworkInterface.
NetworkInterface(String, InetAddress) - Constructor for class org.infinispan.configuration.as.NetworkInterface
 
newCatchThrowableProxy(Object) - Static method in class org.infinispan.util.Proxies
 
newCondition() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
newConfigurationBuilder(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
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.
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
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
newKeySet() - Static method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new Set backed by a ConcurrentHashMapV8 from the given type to Boolean.TRUE.
newKeySet(int) - Static method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Creates a new Set backed by a ConcurrentHashMapV8 from the given type to Boolean.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
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
 
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
 
newTaskFor(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
 
newTaskFor(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
newTaskFor(Runnable, T) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
newThread(ForkJoinPool) - Method in interface org.infinispan.util.concurrent.jdk8backported.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
newVersion(boolean) - Method in class org.infinispan.util.ClusterIdGenerator
 
next() - Method in class org.infinispan.container.DefaultDataContainer.EntryIterator
 
next() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
next(int) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
 
nextComplete() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
If this task does not have a completer, invokes ForkJoinTask.quietlyComplete() and returns null.
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
 
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).
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_FAILOVER - Static variable in class org.infinispan.distexec.DefaultExecutorService
 
NO_OPTIONS - Static variable in class org.infinispan.util.Base64
No options specified.
noAnnotateMethodsFoundInListener(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
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.
noLiveOwnersFoundForSegment(int, String, Collection<Address>, Collection<Address>) - Method in interface org.infinispan.util.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
NonTransactionalBackupInterceptor - Class in org.infinispan.interceptors.xsite
Handles x-site data backups for non-transactional caches.
NonTransactionalBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
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
 
NonTxConcurrentDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Non-transactional interceptor to be used by caches that want to support concurrent writes.
NonTxConcurrentDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.NonTxConcurrentDistributionInterceptor
 
NonTxDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Handles the distribution of the non-transactional caches.
NonTxDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
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
 
NoReturnValuesDistributionResponseGenerator - Class in org.infinispan.remoting.responses
 
NoReturnValuesDistributionResponseGenerator() - Constructor for class org.infinispan.remoting.responses.NoReturnValuesDistributionResponseGenerator
 
normalizedHash(Hash, int) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
NoStateExternalizer<T> - Class in org.infinispan.marshall.exts
An externalizer that writes no state.
NoStateExternalizer() - Constructor for class org.infinispan.marshall.exts.NoStateExternalizer
 
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.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
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
 
notifyCommitEntry(boolean, boolean, boolean, CacheEntry, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
notifyDataRehashed(ConsistentHash, ConsistentHash, int, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyDataRehashed(ConsistentHash, ConsistentHash, int, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.AggregatingNotifyingFutureImpl
 
notifyDone() - Method in class org.infinispan.util.concurrent.BaseNotifyingFuture
 
notifyDone() - Method in class org.infinispan.util.concurrent.DeferredReturnFuture
 
notifyDone() - Method in class org.infinispan.util.concurrent.NoOpFuture
 
notifyDone() - Method in interface org.infinispan.util.concurrent.NotifyingNotifiableFuture
 
notifyEndOfRebalance(int) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
notifyEndOfRebalance(int) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
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.
NotifyingFutureAdaptor<T> - Class in org.infinispan.util.concurrent
Receives a Future and exposes it as an NotifyingFuture.
NotifyingFutureAdaptor() - Constructor for class org.infinispan.util.concurrent.NotifyingFutureAdaptor
 
NotifyingFutureImpl<T> - Class in org.infinispan.util.concurrent
Constructs an instance of a NotifyingFuture.
NotifyingFutureImpl(T) - 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
 
notifyTopologyChanged(ConsistentHash, ConsistentHash, int, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyTopologyChanged(ConsistentHash, ConsistentHash, int, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyTopologyInstalled(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
notifyTopologyInstalled(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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
 
notifyTransactionDataReceived(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
notifyTransactionDataReceived(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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
 
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
 
numSegments() - Method in class org.infinispan.configuration.cache.HashConfiguration
Controls the total number of hash space segments (per cluster).
numSegments(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Controls the total number of hash space segments (per cluster).
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.
No longer used since 5.2, use HashConfigurationBuilder.numSegments(int) instead.
numVirtualNodes() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated.
No longer used since 5.2, replaced by HashConfiguration.numSegments() (which works like a numVirtualNodes value for the entire cluster).
numVirtualNodes(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated.
No longer used since 5.2, replaced by HashConfigurationBuilder.numSegments(int) (which works like a numVirtualNodes value for the entire cluster).

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[]) - 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) - 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
 
OFFLINE - Static variable in class org.infinispan.xsite.XSiteAdminOperations
 
OfflineStatus - Class in org.infinispan.xsite
Keeps state needed for knowing when a site needs to be taken offline.
OfflineStatus(TakeOfflineConfiguration) - Constructor for class org.infinispan.xsite.OfflineStatus
 
oldValue - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
oldValue - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
onCompletion(CountedCompleter<?>) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Performs an action when method CountedCompleter.tryComplete() is invoked and the pending count is zero, or when the unconditional method CountedCompleter.complete(T) is invoked.
onEntryActivated(Object) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionListener
 
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.
onEntryRemoved(Object) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionListener
 
onePhaseCommit - Variable in class org.infinispan.commands.tx.PrepareCommand
 
onExceptionalCompletion(Throwable, CountedCompleter<?>) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Performs an action when method ForkJoinTask.completeExceptionally(java.lang.Throwable) is invoked or method CountedCompleter.compute() throws an exception, and this task has not otherwise already completed normally.
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
ONLINE - Static variable in class org.infinispan.xsite.XSiteAdminOperations
 
onPostExecute(Mapper<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.spi.DefaultMapReduceTaskLifecycle
 
onPostExecute(Reducer<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.spi.DefaultMapReduceTaskLifecycle
 
onPostExecute(Mapper<KIn, VIn, KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycle
 
onPostExecute(Reducer<KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycle
 
onPostExecute(Mapper<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycleService
 
onPostExecute(Reducer<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycleService
 
onPostExecute(Callable<T>) - Method in class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
 
onPostExecute(Callable<T>) - Method in interface org.infinispan.distexec.spi.DistributedTaskLifecycle
 
onPostExecute(Callable<T>) - Method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
 
onPreExecute(Mapper<KIn, VIn, KOut, VOut>, Cache<KIn, VIn>) - Method in class org.infinispan.distexec.mapreduce.spi.DefaultMapReduceTaskLifecycle
 
onPreExecute(Reducer<KOut, VOut>, Cache<?, ?>) - Method in class org.infinispan.distexec.mapreduce.spi.DefaultMapReduceTaskLifecycle
 
onPreExecute(Mapper<KIn, VIn, KOut, VOut>, Cache<KIn, VIn>) - Method in interface org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycle
 
onPreExecute(Reducer<KOut, VOut>, Cache<?, ?>) - Method in interface org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycle
 
onPreExecute(Mapper<KIn, VIn, KOut, VOut>, Cache<KIn, VIn>) - Method in class org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycleService
 
onPreExecute(Reducer<KOut, VOut>, Cache<?, ?>) - Method in class org.infinispan.distexec.mapreduce.spi.MapReduceTaskLifecycleService
 
onPreExecute(Callable<T>, Cache<K, V>) - Method in class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
 
onPreExecute(Callable<T>, Cache<K, V>) - Method in interface org.infinispan.distexec.spi.DistributedTaskLifecycle
 
onPreExecute(Callable<T>, Cache<K, V>) - Method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
 
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.
onStart() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onStateReceived(int, boolean) - Method in class org.infinispan.statetransfer.InboundTransferTask
 
onTermination(Throwable) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinWorkerThread
Performs cleanup associated with termination of this worker thread.
onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
 
onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.transaction.TransactionTable
 
onTopologyUpdate(CacheTopology, boolean) - Method in interface org.infinispan.statetransfer.StateConsumer
Receive notification of topology changes.
onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
onTopologyUpdate(CacheTopology, boolean) - Method in interface org.infinispan.statetransfer.StateProvider
Receive notification of topology changes.
onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
Operation<K,V> - Class in org.infinispan.atomic
An atomic operation.
Operation() - Constructor for class org.infinispan.atomic.Operation
 
OptimisticBackupInterceptor - Class in org.infinispan.interceptors.xsite
Handles x-site data backups for optimistic transactional caches.
OptimisticBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
 
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
 
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.commands - package org.infinispan.commands
Commands that operate on the cache, either locally or remotely.
org.infinispan.commands.control - package org.infinispan.commands.control
 
org.infinispan.commands.module - package org.infinispan.commands.module
 
org.infinispan.commands.read - package org.infinispan.commands.read
 
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.as - package org.infinispan.configuration.as
 
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.distexec - package org.infinispan.distexec
 
org.infinispan.distexec.mapreduce - package org.infinispan.distexec.mapreduce
 
org.infinispan.distexec.mapreduce.spi - package org.infinispan.distexec.mapreduce.spi
 
org.infinispan.distexec.spi - package org.infinispan.distexec.spi
 
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.distribution.topologyaware - package org.infinispan.distribution.topologyaware
 
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.distribution - package org.infinispan.interceptors.distribution
 
org.infinispan.interceptors.locking - package org.infinispan.interceptors.locking
 
org.infinispan.interceptors.xsite - package org.infinispan.interceptors.xsite
 
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.bucket - package org.infinispan.loaders.bucket
Abstract classes that use hashed buckets to store entries.
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.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.manager - package org.infinispan.manager
Cache manager package
org.infinispan.marshall - package org.infinispan.marshall
Infinispan makes use of custom marshalling to serialize and deserialize state wherever possible, rather than falling back to the JDK to do this.
org.infinispan.marshall.exts - package org.infinispan.marshall.exts
Externalizers for various JDK types that are marshalled using the marshalling framework.
org.infinispan.marshall.jboss - package org.infinispan.marshall.jboss
Hooks to bridge Infinispan's marshalling APIs with JBoss Marshalling internals.
org.infinispan.notifications - package org.infinispan.notifications
Notifications and eventing for listeners on both the Cache and CacheManager interfaces.
org.infinispan.notifications.cachelistener - package org.infinispan.notifications.cachelistener
Cache-specific notifications and eventing.
org.infinispan.notifications.cachelistener.annotation - package org.infinispan.notifications.cachelistener.annotation
 
org.infinispan.notifications.cachelistener.event - package org.infinispan.notifications.cachelistener.event
 
org.infinispan.notifications.cachemanagerlistener - package org.infinispan.notifications.cachemanagerlistener
CacheManager-specific notifications and eventing.
org.infinispan.notifications.cachemanagerlistener.annotation - package org.infinispan.notifications.cachemanagerlistener.annotation
 
org.infinispan.notifications.cachemanagerlistener.event - package org.infinispan.notifications.cachemanagerlistener.event
 
org.infinispan.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.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.topology - package org.infinispan.topology
 
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.upgrade - package org.infinispan.upgrade
 
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
 
org.infinispan.xsite - package org.infinispan.xsite
 
originalAwaitInitialTransfer() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
We want to remember if the user didn't configure awaitInitialTransfer for the default cache.
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
 
OutboundSocketBinding - Class in org.infinispan.configuration.as
OutboundSocketBinding.
OutboundSocketBinding(String, String, int) - Constructor for class org.infinispan.configuration.as.OutboundSocketBinding
 
OutboundTransferTask - Class in org.infinispan.statetransfer
Outbound state transfer task.
OutboundTransferTask(Address, Set<Integer>, int, int, ConsistentHash, StateProviderImpl, DataContainer, CacheLoaderManager, RpcManager, CommandsFactory, long, String) - Constructor for class org.infinispan.statetransfer.OutboundTransferTask
 
OutdatedTopologyException - Exception in org.infinispan.statetransfer
An exception signalling that a command should be retried because it was executed with an outdated topology.
OutdatedTopologyException(String) - Constructor for exception org.infinispan.statetransfer.OutdatedTopologyException
 
OutdatedTopologyException(String, Throwable) - Constructor for exception org.infinispan.statetransfer.OutdatedTopologyException
 
overriddenConfigurationElements - Variable in class org.infinispan.config.AbstractConfigurationBean
 
override(OverrideConfigurationVisitor) - Method in class org.infinispan.config.OverrideConfigurationVisitor
 
OverrideConfigurationVisitor - Class in org.infinispan.config
OverrideConfigurationVisitor breaks down fields of Configuration object to individual components and then compares them for field updates.
OverrideConfigurationVisitor() - Constructor for class org.infinispan.config.OverrideConfigurationVisitor
 
OwnableReentrantLock - Class in org.infinispan.util.concurrent.locks
A lock that supports reentrancy based on owner (and not on current thread).
OwnableReentrantLock() - 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.
OwnableRefCountingReentrantLock - Class in org.infinispan.util.concurrent.locks
A version of OwnableReentrantLock that has a reference counter, and implements RefCountingLock.
OwnableRefCountingReentrantLock() - Constructor for class org.infinispan.util.concurrent.locks.OwnableRefCountingReentrantLock
 
OwnershipStatistics - Class in org.infinispan.distribution.ch
This class holds statistics about a consistent hash.
OwnershipStatistics(List<Address>) - Constructor for class org.infinispan.distribution.ch.OwnershipStatistics
 
OwnershipStatistics(DefaultConsistentHash, List<Address>) - Constructor for class org.infinispan.distribution.ch.OwnershipStatistics
 
OwnershipStatistics(OwnershipStatistics) - Constructor for class org.infinispan.distribution.ch.OwnershipStatistics
 
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
 
Parameter - Annotation Type in org.infinispan.jmx.annotations
 
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.ParserRegistry
 
parseAsyncStore(XMLExtendedStreamReader, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
 
parseCacheAttribute(XMLExtendedStreamReader, int, Attribute, String, ConfigurationBuilder) - Method in class org.infinispan.configuration.as.ParserAS7
 
parseCacheElement(XMLExtendedStreamReader, Element, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.as.ParserAS7
 
parseCommonLoaderAttributes(XMLExtendedStreamReader, int, CacheLoaderConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
This method is public static so that it can be reused by custom cache store/loader configuration parsers
parseCommonLoaderChildren(XMLExtendedStreamReader, CacheLoaderConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
 
parseCommonStoreAttributes(XMLExtendedStreamReader, int, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
This method is public static so that it can be reused by custom cache store/loader configuration parsers
parseCommonStoreChildren(XMLExtendedStreamReader, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
 
parseCustomStore(XMLExtendedStreamReader, LegacyStoreConfigurationBuilder) - Method in class org.infinispan.configuration.as.ParserAS7
 
parseDefaultConfiguration() - Method in class org.infinispan.config.InfinispanConfiguration
Deprecated.
 
parseDefaultConfiguration() - Method in interface org.infinispan.config.parsing.XmlConfigurationParser
Parses the default template configuration.
parseEviction(XMLExtendedStreamReader, ConfigurationBuilder) - Method in class org.infinispan.configuration.as.ParserAS7
 
parseFile(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parseFileStore(XMLExtendedStreamReader, FileCacheStoreConfigurationBuilder) - Method in class org.infinispan.configuration.as.ParserAS7
 
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

parseLocking(XMLExtendedStreamReader, ConfigurationBuilder) - Method in class org.infinispan.configuration.as.ParserAS7
 
parseLockSupportStoreAttributes(XMLExtendedStreamReader, int, LockSupportStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
This method is public static so that it can be reused by custom cache store/loader configuration parsers
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.
parseProperties(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.Parser51
 
parseProperties(XMLExtendedStreamReader) - Static method in class org.infinispan.configuration.parsing.Parser52
 
Parser - Class in org.infinispan.configuration.parsing
Deprecated.
Parser(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.Parser
Deprecated.
 
Parser51 - Class in org.infinispan.configuration.parsing
This class implements the parser for 5.1 schema files
Parser51() - Constructor for class org.infinispan.configuration.parsing.Parser51
 
Parser52 - Class in org.infinispan.configuration.parsing
This class implements the parser for 5.2 schema files
Parser52() - Constructor for class org.infinispan.configuration.parsing.Parser52
 
ParserAS7 - Class in org.infinispan.configuration.as
This class implements the parser for AS7/EAP/JDG schema files
ParserAS7() - Constructor for class org.infinispan.configuration.as.ParserAS7
 
ParserContext - Interface in org.infinispan.configuration.parsing
 
ParserContextAS7 - Class in org.infinispan.configuration.as
ParserContextAS7.
ParserContextAS7() - Constructor for class org.infinispan.configuration.as.ParserContextAS7
 
ParserContextListener - Interface in org.infinispan.configuration.parsing
ParserContextListener.
parseResponseAndAddToResponseList(Object, Throwable, Map<Address, Response>, boolean, boolean, Address, boolean, boolean) - Method in class org.infinispan.remoting.transport.AbstractTransport
 
ParserRegistry - Class in org.infinispan.configuration.parsing
ParserRegistry.
ParserRegistry(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
 
parseSingletonStore(XMLExtendedStreamReader, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser52
 
parseStoreAttribute(XMLExtendedStreamReader, int, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.as.ParserAS7
 
parseStoreElement(XMLExtendedStreamReader, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.as.ParserAS7
 
parseStoreProperty(XMLExtendedStreamReader, CacheStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.as.ParserAS7
 
parseStoreWriteBehind(XMLExtendedStreamReader, AsyncStoreConfigurationBuilder) - Static method in class org.infinispan.configuration.as.ParserAS7
 
parseTransaction(XMLExtendedStreamReader, ConfigurationBuilder) - Method in class org.infinispan.configuration.as.ParserAS7
 
ParseUtils - Class in org.infinispan.configuration.parsing
 
parsingComplete(ParserContext) - Method in interface org.infinispan.configuration.parsing.ParserContextListener
 
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
 
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
 
peekNextLocalTask() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Returns, but does not unschedule or execute, a task queued by the current thread but not yet executed, if one is immediately available.
perform(InvocationContext) - Method in class org.infinispan.commands.CancelCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.control.LockControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.CreateCacheCommand
 
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.GetCacheEntryCommand
 
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.MapCombineCommand
Performs invocation of mapping phase and local combine phase on assigned Infinispan node
perform(InvocationContext) - Method in class org.infinispan.commands.read.ReduceCommand
Performs invocation of reduce phase on assigned Infinispan 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.CommitCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.tx.PrepareCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.tx.RollbackCommand
 
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.statetransfer.StateRequestCommand
 
perform(InvocationContext) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
perform(InvocationContext) - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
perform(InvocationContext) - Method in class org.infinispan.xsite.XSiteAdminCommand
 
performCheckOnKey(Object) - Method in interface org.infinispan.transaction.WriteSkewHelper.KeySpecificLogic
 
performLocalWriteSkewCheck(DataContainer, boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
performWriteSkewCheck(DataContainer, TxInvocationContext) - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
performWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, DataContainer, VersionGenerator, TxInvocationContext, WriteSkewHelper.KeySpecificLogic) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
PessimisticBackupInterceptor - Class in org.infinispan.interceptors.xsite
Handles x-site data backups for pessimistic transactional caches.
PessimisticBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.PessimisticBackupInterceptor
 
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
 
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
pollNextLocalTask() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if the current thread is operating in a ForkJoinPool.
pollSubmission() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollTask() - Static method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
If the current thread is operating in a ForkJoinPool, unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if one is available, or if not available, a task that was forked by some other thread, if available.
popNDC(boolean) - Static method in class org.infinispan.util.logging.BasicLogFactory
 
popNDC(boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
populateOwnersFewSegments(SyncConsistentHashFactory.Builder, SortedMap<Integer, Address>) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
populateOwnersFewSegments(SyncConsistentHashFactory.Builder, SortedMap<Integer, Address>) - Method in class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory
 
populateOwnersManySegments(SyncConsistentHashFactory.Builder, SortedMap<Integer, Address>) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
populateOwnersManySegments(SyncConsistentHashFactory.Builder, SortedMap<Integer, Address>) - Method in class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory
 
port() - Method in class org.infinispan.configuration.as.OutboundSocketBinding
 
port() - Method in class org.infinispan.configuration.as.SocketBinding
 
portOffset() - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
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
 
possiblyLocked(CacheEntry) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Inspects the entry for signs that it is possibly locked, and hence would need to be unlocked.
possiblyLocked(CacheEntry) - Method in class org.infinispan.util.concurrent.locks.LockManagerImpl
 
preload - 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.
prepare(List<? extends Modification>, GlobalTransaction, boolean) - Method in class org.infinispan.loaders.AbstractCacheStore
 
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
 
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.distribution.TxDistributionInterceptor
 
prepareOnAffectedNodes(TxInvocationContext, PrepareCommand, Collection<Address>, boolean) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
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
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.
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
 
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, Throwable) - 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
 
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
 
processResponses(BackupResponse, VisitableCommand) - Method in interface org.infinispan.xsite.BackupSender
Processes the responses of a backup command.
processResponses(BackupResponse, VisitableCommand, Transaction) - Method in interface org.infinispan.xsite.BackupSender
 
processResponses(BackupResponse, VisitableCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
processResponses(BackupResponse, VisitableCommand, Transaction) - Method in class org.infinispan.xsite.BackupSenderImpl
 
processVisitableCommand(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
PROJECT_NAME - Static variable in class org.infinispan.Version
 
propagateCompletion() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Equivalent to CountedCompleter.tryComplete() but does not invoke CountedCompleter.onCompletion(org.infinispan.util.concurrent.jdk8backported.CountedCompleter) along the completion path: If the pending count is nonzero, decrements the count; otherwise, similarly tries to complete this task's completer, if one exists, else marks this task as complete.
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 - Variable in class org.infinispan.configuration.cache.AbstractLoaderConfigurationBuilder
 
properties() - Method in interface org.infinispan.configuration.cache.CacheLoaderConfiguration
 
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
 
Proxies - Class in org.infinispan.util
Proxies is a collection of useful dynamic profixes.
Proxies() - Constructor for class org.infinispan.util.Proxies
 
pruneInvalidMembers(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
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.file.FileCacheStore
 
purgeOnStartup() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
If true, purges this cache store when it starts up.
purgeOnStartup - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
purgeOnStartup(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
If true, purges this cache store when it starts up.
purgeOnStartup(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
purgeOnStartup() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
If true, purges this cache store when it starts up.
purgeOnStartup(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
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.AbstractStoreConfiguration
The number of threads to use when purging asynchronously.
purgerThreads - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
purgerThreads(int) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
The number of threads to use when purging asynchronously.
purgerThreads(int) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
purgerThreads() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
The number of threads to use when purging asynchronously.
purgerThreads(int) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
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.AbstractStoreConfiguration
If true, CacheStore#purgeExpired() call will be done synchronously
purgeSynchronously - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
purgeSynchronously(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
If true, CacheStore#purgeExpired() call will be done synchronously
purgeSynchronously(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
purgeSynchronously() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
If true, CacheStore#purgeExpired() call will be done synchronously
purgeSynchronously(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
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
 
pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.BasicLogFactory
 
pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
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(long, TimeUnit) - 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.
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) - Method in interface org.infinispan.api.BasicCache
If the return value of this operation will be ignored by the application, the user is strongly encouraged to use the Flag.IGNORE_RETURN_VALUES flag when invoking this method in order to make it behave as efficiently as possible (i.e.
put(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
An overloaded form of BasicCache.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 BasicCache.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(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(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
 
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) - 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 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
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
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>) - 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 BasicCache.put(Object, Object).
putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
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) - 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
 
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(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 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
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
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) - 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
 
PutKeyValueCommand - Class in org.infinispan.commands.write
Implements functionality defined by BasicCache.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 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.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
 
putLookedUpRemoteVersion(Object, EntryVersion) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
putLookedUpRemoteVersion(Object, EntryVersion) - 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.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
 
quietlyComplete() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Completes this task normally without setting a value.
quietlyCompleteRoot() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Equivalent to getRoot().quietlyComplete().
quietlyInvoke() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Commences performing this task and awaits its completion if necessary, without returning its result or throwing its exception.
quietlyJoin() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Joins this task, without returning its result or throwing its exception.

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.
RANDOM_NODE_FAILOVER - Static variable in class org.infinispan.distexec.DefaultExecutorService
 
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(T) - Method in interface org.infinispan.configuration.Builder
Reads the configuration from an already created configuration bean into this builder.
read(AsyncConfiguration) - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
read(AsyncStoreConfiguration) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
read(BackupConfiguration) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
read(BackupForConfiguration) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
read(ClusterCacheLoaderConfiguration) - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
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(LegacyLoaderConfiguration) - Method in class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
 
read(LegacyStoreConfiguration) - Method in class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
 
read(LegacyStoreConfiguration) - 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(SitesConfiguration) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
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(TakeOfflineConfiguration) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
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(ExecutorFactoryConfiguration) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
read(GlobalConfiguration) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
read(GlobalJmxStatisticsConfiguration) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
read(ScheduledExecutorFactoryConfiguration) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
read(SerializationConfiguration) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
read(ShutdownConfiguration) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
read(SiteConfiguration) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
read(TransportConfiguration) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
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.
ReadableGridFileChannel - Class in org.infinispan.io
 
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.io.UnclosableObjectInputStream
 
readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
ReadCommittedEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
ReadCommittedEntry() - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry(Object, Object, 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
 
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.as.ParserAS7
 
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser51
 
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser52
 
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.util.ImmutableListCopy
readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readManagedAttributeAlreadyPresent(Method) - Method in interface org.infinispan.util.logging.Log
 
readMetadata(URL) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
 
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.DeltaCompositeKey.DeltaCompositeKeyExternalizer
 
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.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.DefaultConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory.Externalizer
 
readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject(ObjectInput) - Method in class org.infinispan.loaders.bucket.Bucket.Externalizer
 
readObject(ObjectInput) - Method in interface org.infinispan.marshall.Externalizer
Read an instance from the stream.
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ArrayListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.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.CacheNotFoundResponse.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.StateChunk.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.topology.CacheTopology.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.util.ByteArrayKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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
 
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.io.UnclosableObjectInputStream
 
readUTF() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readVersionsFromResponse(Response, CacheTransaction) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
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.
reaperWakeUpInterval() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
reaperWakeUpInterval(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
The time interval (millis) at which the thread that cleans up transaction completion information kicks in.
rebalance(CH) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Create a new consistent hash instance, based on an existing instance, but "balanced" according to the implementation's rules.
rebalance(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
rebalance(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
rebalance(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
rebalance(CacheTopology) - Method in interface org.infinispan.topology.CacheTopologyHandler
Invoked when state transfer has to be started.
rebalanceBuilder(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
rebalanceError(String, Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
RebalancePolicy - Interface in org.infinispan.topology
Processes cache membership changes or any other events and decides when to rebalance state between members.
rebalanceStartError(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
recalculateMinTopologyIdIfNeeded(CacheTransaction) - 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 gate, that uses an AbstractQueuedSynchronizer.
ReclosableLatch() - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
ReclosableLatch(boolean) - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
 
recordKnownGlobalKeyset() - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
recordKnownGlobalKeyset() - Method in interface org.infinispan.upgrade.SourceMigrator
Records all known keys and stores them under a well-known key which can be used for retrieval.
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.
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(ReduceCommand<KOut, VOut>) - Method in interface org.infinispan.distexec.mapreduce.MapReduceManager
Invoked when ReduceCommand arrives to a target Infinispan node.
reduce(ReduceCommand<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
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.
reduce(long, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all (key, value) pairs using the given reducer to combine values, or null if none.
ReduceCommand<KOut,VOut> - Class in org.infinispan.commands.read
ReduceCommand is a container to migrate Reducer to a remote Infinispan node where it will get executed and return the result to an invoking/master node.
ReduceCommand(String) - Constructor for class org.infinispan.commands.read.ReduceCommand
 
ReduceCommand(String, Reducer<KOut, VOut>, String, Collection<KOut>) - Constructor for class org.infinispan.commands.read.ReduceCommand
 
reducedWith(Reducer<KOut, VOut>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Specifies Reducer to use for this MapReduceTask
reduceEntries(long, ConcurrentHashMapV8.BiFun<Map.Entry<K, V>, Map.Entry<K, V>, ? extends Map.Entry<K, V>>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating all entries using the given reducer to combine values, or null if none.
reduceEntries(long, ConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all entries using the given reducer to combine values, or null if none.
reduceEntriesToDouble(long, ConcurrentHashMapV8.ObjectToDouble<Map.Entry<K, V>>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all entries using the given reducer to combine values, and the given basis as an identity value.
reduceEntriesToInt(long, ConcurrentHashMapV8.ObjectToInt<Map.Entry<K, V>>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all entries using the given reducer to combine values, and the given basis as an identity value.
reduceEntriesToLong(long, ConcurrentHashMapV8.ObjectToLong<Map.Entry<K, V>>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all entries using the given reducer to combine values, and the given basis as an identity value.
reduceKeys(long, ConcurrentHashMapV8.BiFun<? super K, ? super K, ? extends K>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating all keys using the given reducer to combine values, or null if none.
reduceKeys(long, ConcurrentHashMapV8.Fun<? super K, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all keys using the given reducer to combine values, or null if none.
reduceKeysToDouble(long, ConcurrentHashMapV8.ObjectToDouble<? super K>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all keys using the given reducer to combine values, and the given basis as an identity value.
reduceKeysToInt(long, ConcurrentHashMapV8.ObjectToInt<? super K>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all keys using the given reducer to combine values, and the given basis as an identity value.
reduceKeysToLong(long, ConcurrentHashMapV8.ObjectToLong<? super K>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all keys using the given reducer to combine values, and the given basis as an identity value.
reducer - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
Reducer<KOut,VOut> - Interface in org.infinispan.distexec.mapreduce
Reduces intermediate key/value results from map phase of MapReduceTask.
reduceToDouble(long, ConcurrentHashMapV8.ObjectByObjectToDouble<? super K, ? super V>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all (key, value) pairs using the given reducer to combine values, and the given basis as an identity value.
reduceToInt(long, ConcurrentHashMapV8.ObjectByObjectToInt<? super K, ? super V>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all (key, value) pairs using the given reducer to combine values, and the given basis as an identity value.
reduceToLong(long, ConcurrentHashMapV8.ObjectByObjectToLong<? super K, ? super V>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all (key, value) pairs using the given reducer to combine values, and the given basis as an identity value.
reduceValues(long, ConcurrentHashMapV8.BiFun<? super V, ? super V, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating all values using the given reducer to combine values, or null if none.
reduceValues(long, ConcurrentHashMapV8.Fun<? super V, ? extends U>, ConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all values using the given reducer to combine values, or null if none.
reduceValuesToDouble(long, ConcurrentHashMapV8.ObjectToDouble<? super V>, double, ConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all values using the given reducer to combine values, and the given basis as an identity value.
reduceValuesToInt(long, ConcurrentHashMapV8.ObjectToInt<? super V>, int, ConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all values using the given reducer to combine values, and the given basis as an identity value.
reduceValuesToLong(long, ConcurrentHashMapV8.ObjectToLong<? super V>, long, ConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns the result of accumulating the given transformation of all values using the given reducer to combine values, and the given basis as an identity value.
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.
RefCountingLock - Interface in org.infinispan.util.concurrent.locks
An extension of a JDK Lock, with support for maintaining a reference counter.
ReflectionUtil - Class in org.infinispan.util
Basic reflection utilities to enhance what the JDK provides.
ReflectionUtil() - Constructor for class org.infinispan.util.ReflectionUtil
 
register(Thread, UUID) - Method in interface org.infinispan.commands.CancellationService
Registers thread with CancellationService under the given UUID id
register(Thread, UUID) - Method in class org.infinispan.commands.CancellationServiceImpl
 
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.
registerDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.AbstractComponentRegistry
Registers the default class loader.
registerInDoubtTransaction(RecoveryAwareRemoteTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
registerLockedKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
registerMBean(Object, 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
Registers a set of MBean components and returns true if successfully registered; false otherwise.
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.
registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
Register a Synchronization callback with this transaction.
rehashCommandReceivedOnNonDistributedCache() - Method in interface org.infinispan.util.logging.Log
 
rehashDisabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
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
rehashEnabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
rehashEnabled(boolean) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
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.
 
rehashRpcTimeout() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated.
rehashRpcTimeout(long) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
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.
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
 
reinitialize() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
releaseAllLocks(List<Object>) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases locks on all keys passed in.
releaseExclusiveTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseExclusiveTopologyLock() - 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
 
releaseSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
remoteCache(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
remoteCache() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
remoteCallTimeout() - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfiguration
 
remoteCallTimeout(long) - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
remoteCallTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
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
 
RemoteException - Exception in org.infinispan.remoting
Represents an application-level exception originating in a remote node.
RemoteException(String, Throwable) - Constructor for exception org.infinispan.remoting.RemoteException
 
remoteException(Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
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
 
remoteSite(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
remoteSite() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
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
 
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 interface org.infinispan.api.BasicCache
If the return value of this operation will be ignored by the application, the user is strongly encouraged to use the Flag.IGNORE_RETURN_VALUES flag when invoking this method in order to make it behave as efficiently as possible (i.e.
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(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 interface org.infinispan.loaders.CacheStore
Removes an entry in the store.
remove(Object) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
remove(Object) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
remove(Object) - Method in class org.infinispan.loaders.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() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
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.KeySetView
Removes the key from this map view, by removing the key (and its corresponding value) from the backing map.
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
 
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.AsyncStore
 
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 BasicCache.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.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, CacheLoaderManager) - Constructor for class org.infinispan.commands.RemoveCacheCommand
 
removeCacheLoader(String) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
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
 
removeEntry(Object) - Method in class org.infinispan.loaders.bucket.Bucket
 
removeExpiredEntries() - Method in class org.infinispan.loaders.bucket.Bucket
 
removeExtraBackupOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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(LocalTransaction) - 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, 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.SingleKeyNonTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
removeMember(Address) - Method in class org.infinispan.topology.ClusterCacheStatus
 
RemoveOperation<K,V> - Class in org.infinispan.atomic
An atomic remove operation.
RemoveOperation() - Constructor for class org.infinispan.atomic.RemoveOperation
 
RemoveOperation.Externalizer - Class in org.infinispan.atomic
 
RemoveOperation.Externalizer() - Constructor for class org.infinispan.atomic.RemoveOperation.Externalizer
 
removeOwner(int, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
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
 
renameTo(File) - Method in class org.infinispan.io.GridFile
 
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(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, 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(String, String, BackupReceiver) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
replaceAll(ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
 
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
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
replaceAsync(K, V, V) - Method in interface org.infinispan.api.BasicCache
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
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) - 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
 
replaceBackupOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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
 
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
 
replacePrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
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.
replaceValue(Object, Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
replaceValue(Object, Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
replaceValue(Object, Object) - Method in interface org.infinispan.context.InvocationContext
Tries to replace the value of the wrapped entry associated with the given key in the context, if one exists.
replaceValue(Object, Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
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
 
REPLICATED_CONSISTENT_HASH - Static variable in interface org.infinispan.marshall.Ids
 
REPLICATED_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.Ids
 
ReplicatedConsistentHash - Class in org.infinispan.distribution.ch
Special implementation of ConsistentHash for replicated caches.
ReplicatedConsistentHash(List<Address>) - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
ReplicatedConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
ReplicatedConsistentHash.Externalizer() - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHash.Externalizer
 
ReplicatedConsistentHashFactory - Class in org.infinispan.distribution.ch
Factory for ReplicatedConsistentHash.
ReplicatedConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
ReplicatedConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch
 
ReplicatedConsistentHashFactory.Externalizer() - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory.Externalizer
 
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
 
replicationTimeout() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
replicationTimeout(long) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Timeout(millis) used for replicating calls to other sites.
replicationTimeout() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
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.
replQueueInterval(long, TimeUnit) - 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.
replTimeout(long, TimeUnit) - 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_IGNORED_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
requestSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
Send START_STATE_TRANSFER request to source node.
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.
reset() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
reset() - Method in interface org.infinispan.context.FlagContainer
Deprecated.
 
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.util.concurrent.jdk8backported.LongAdder
Resets variables maintaining the sum to zero.
reset() - Method in class org.infinispan.xsite.OfflineStatus
 
resetPassivationCount() - Method in interface org.infinispan.eviction.PassivationManager
 
resetPassivationCount() - Method in class org.infinispan.eviction.PassivationManagerImpl
 
resetStatistics() - Method in class org.infinispan.eviction.ActivationManagerImpl
 
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.
resolveCacheLoader() - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
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
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
 
retrieveFromRemoteSource(Object, InvocationContext, boolean, FlagAffectedCommand) - Method in class org.infinispan.interceptors.ClusteringInterceptor
Retrieves a cache entry from a remote source.
retrieveFromRemoteSource(Object, InvocationContext, boolean, FlagAffectedCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
retrieveFromRemoteSource(Object, InvocationContext, boolean, FlagAffectedCommand) - Method in class org.infinispan.interceptors.ReplicationInterceptor
 
retrievingTm(TransactionManager) - Method in interface org.infinispan.util.logging.Log
 
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
 
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
 
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(GlobalTransaction) - Method in class org.infinispan.loaders.AbstractCacheStore
 
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
 
RollingUpgradeManager - Class in org.infinispan.upgrade
This component handles the control hooks to handle migrating from one version of Infinispan to another.
RollingUpgradeManager() - Constructor for class org.infinispan.upgrade.RollingUpgradeManager
 
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 - Variable in class org.infinispan.interceptors.TxInterceptor
 
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.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.statetransfer.OutboundTransferTask
 
run() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.
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
 
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
 
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_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(long, ConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a non-null result from applying the given search function on each (key, value), or null if none.
searchEntries(long, ConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a non-null result from applying the given search function on each entry, or null if none.
searchKeys(long, ConcurrentHashMapV8.Fun<? super K, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a non-null result from applying the given search function on each key, or null if none.
searchValues(long, ConcurrentHashMapV8.Fun<? super V, ? extends U>) - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8
Returns a non-null result from applying the given search function on each value, or null if none.
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in interface org.infinispan.util.logging.Log
 
selectExecutionNode(List<Address>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
selectExecutionNode(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
self() - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.LoaderConfigurationBuilder
 
Self<S extends Self<S>> - Interface in org.infinispan.configuration
This interface simplifies the task of writing fluent builders which need to inherit from other builders (abstract or concrete).
self() - Method in interface org.infinispan.configuration.Self
 
sendCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
sendNotification(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
sendNotification(Object, Object, boolean, InvocationContext) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
SEPARATOR - Static variable in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
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() - 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
 
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(T) - Method in class org.infinispan.util.ByRef
 
set(int, E) - Method in class org.infinispan.util.ForwardingList
 
setActual(Future<T>) - Method in class org.infinispan.util.concurrent.NotifyingFutureAdaptor
 
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
setAlwaysProvideInMemoryState(boolean) - Method in class org.infinispan.config.Configuration
setAlwaysProvideInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.
The visibility of this will be reduced, use Configuration.StateRetrievalType.alwaysProvideInMemoryState(Boolean) instead
setAsText(String) - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder.FsyncModeEditor
Deprecated.
 
setAsText(String) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig.FsyncModeEditor
 
setAsyncListenerExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
Use FluentGlobalTypes.asyncListenerExecutor() instead
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
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.
setAsyncStoreConfig(AsyncStoreConfig) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setAsyncTransportExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
Use FluentGlobalTypes.asyncTransportExecutor() instead
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
setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
 
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..
setBucketId(Integer) - Method in class org.infinispan.loaders.bucket.Bucket
 
setBucketId(String) - Method in class org.infinispan.loaders.bucket.Bucket
 
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
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
setCacheManagerNotifier(CacheManagerNotifier) - Method in class org.infinispan.factories.ComponentRegistry
 
setCacheMode(Configuration.CacheMode) - Method in class org.infinispan.config.Configuration
setCacheMode(String) - Method in class org.infinispan.config.Configuration
setCacheModeString(String) - Method in class org.infinispan.config.Configuration
setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheStopTimeout(int) - Method in class org.infinispan.config.Configuration
setCacheStopTimeout(Integer) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
The visibility of this will be reduced, use Configuration.TransactionType.cacheStopTimeout(Integer) instead
setCacheStoreConfig(AbstractCacheStoreConfig) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setChanged(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setChanged(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setChanged(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setChanged(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
 
setChanged(boolean) - 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.SingleKeyNonTxInvocationContext
 
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
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration
setClusterName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.clusterName(String) instead
setCoinToss(long) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Sets the random number that defines the coin toss.
setCompletionFailed(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
 
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
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(Configuration) - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
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
setConsistentHashClass(String) - Method in class org.infinispan.config.Configuration
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
 
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration.CustomInterceptorsType
setCustomInterceptors(List<CustomInterceptorConfig>) - Method in class org.infinispan.config.Configuration
setDeadlockDetectionSpinDuration(long) - Method in class org.infinispan.config.Configuration
setDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.InternalCacheFactory
Allows users to specify a default class loader to use for both the construction and running of the cache.
setDelegate(CacheStore) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
setDependencies(DataContainer) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
setDependencies(LockManager, DataContainer, EntryFactory, 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
setDistributedSyncTimeout(Long) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.distributedSyncTimeout(Long) instead
setEagerLockSingleNode(boolean) - Method in class org.infinispan.config.Configuration
setEagerLockSingleNode(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
The visibility of this will be reduced, use Configuration.TransactionType.eagerLockSingleNode(Boolean) instead
setEmitCompositeIntermediateKeys(boolean) - Method in class org.infinispan.commands.read.MapCombineCommand
 
setEmitCompositeIntermediateKeys(boolean) - Method in class org.infinispan.commands.read.ReduceCommand
 
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
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
 
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.
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
setEvictionScheduledExecutorFactoryClass(String) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
Use FluentGlobalTypes.evictionScheduledExecutor() instead
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
setEvictionStrategy(EvictionStrategy) - Method in class org.infinispan.config.Configuration
setEvictionStrategy(String) - Method in class org.infinispan.config.Configuration
setEvictionThreadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.config.Configuration
setEvictionThreadPolicy(String) - Method in class org.infinispan.config.Configuration
setEvictionWakeUpInterval(long) - Method in class org.infinispan.config.Configuration
setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
setExecutable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setExecutable(boolean) - Method in class org.infinispan.io.GridFile
 
setExpirationLifespan(long) - Method in class org.infinispan.config.Configuration
setExpirationMaxIdle(long) - Method in class org.infinispan.config.Configuration
setExposeGlobalJmxStatistics(boolean) - Method in class org.infinispan.config.GlobalConfiguration
Deprecated.
Use AbstractConfigurationBeanWithGCR.globalJmxStatistics() instead
setExposeJmxStatistics(boolean) - Method in class org.infinispan.config.Configuration
Deprecated.
Use AbstractFluentConfigurationBean.jmxStatistics() instead
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
setFetchInMemoryState(Boolean) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.
The visibility of this will be reduced, use Configuration.StateRetrievalType.fetchInMemoryState(Boolean) instead
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
setFetchPersistentState(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
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(Set<Flag>) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
setFlags(Flag...) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
setFlags(Set<Flag>) - Method in class org.infinispan.commands.control.LockControlCommand
 
setFlags(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(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 class org.infinispan.commands.remote.ClusteredGetCommand
 
setFlags(Flag...) - Method in interface org.infinispan.context.FlagContainer
Deprecated.
 
setFlags(Collection<Flag>) - Method in interface org.infinispan.context.FlagContainer
Deprecated.
 
setFlushLockTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
Deprecated.
The visibility of this method will be reduced. Use AsyncStoreConfig.flushLockTimeout(Long) instead.
setForkJoinTaskTag(short) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Atomically sets the tag value for this task.
setForwarded(boolean) - Method in class org.infinispan.commands.write.PutMapCommand
 
setFromRemoteSite(boolean) - Method in class org.infinispan.transaction.LocalTransaction
 
setFromStateTransfer(boolean) - Method in class org.infinispan.transaction.LocalTransaction
 
setFsyncInterval(long) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setFsyncMode(FileCacheStoreConfig.FsyncMode) - Method in class org.infinispan.loaders.file.FileCacheStoreConfig
 
setGlobalConfiguration(GlobalConfiguration) - Method in class org.infinispan.config.Configuration
Deprecated.
 
setGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.control.LockControlCommand
 
setGroups(GroupsConfiguration) - Method in class org.infinispan.config.Configuration.HashType
Deprecated.
 
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
setHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration.ShutdownType
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
 
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
setIgnoreModifications(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setIgnorePreviousValue(boolean) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
setIgnorePreviousValue(boolean) - Method in class org.infinispan.commands.write.ClearCommand
 
setIgnorePreviousValue(boolean) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setIgnorePreviousValue(boolean) - Method in class org.infinispan.commands.write.PutMapCommand
 
setIgnorePreviousValue(boolean) - Method in class org.infinispan.commands.write.RemoveCommand
 
setIgnorePreviousValue(boolean) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setIgnorePreviousValue(boolean) - Method in interface org.infinispan.commands.write.WriteCommand
Only relevant for conditional commands.
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.
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
setIndexLocalOnly(Boolean) - Method in class org.infinispan.config.Configuration.QueryConfigurationBean
setIndexLocalOnly(boolean) - Method in class org.infinispan.config.Configuration
setInfinispanMarshaller(StreamingMarshaller) - Method in class org.infinispan.marshall.jboss.ExtendedRiverUnmarshaller
 
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
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration.LockingType
Deprecated.
setIsolationLevel(IsolationLevel) - Method in class org.infinispan.config.Configuration
setIsolationLevel(String) - Method in class org.infinispan.config.Configuration
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
setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
setKey(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setKey(K) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setKeys(Object[]) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
setL1CacheEnabled(boolean) - Method in class org.infinispan.config.Configuration
Deprecated.
Use AbstractFluentConfigurationBean.l1() instead
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
setL1Lifespan(long) - Method in class org.infinispan.config.Configuration
setL1OnRehash(boolean) - Method in class org.infinispan.config.Configuration
setLast(boolean) - Method in class org.infinispan.config.CustomInterceptorConfig
Shall this interceptor be the last one in the chain?
setLastModified(long) - Method in class org.infinispan.io.GridFile
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
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
 
setLoaded(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setLoaded(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setLoaded(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setLoaded(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
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.file.FileCacheStoreConfig
Deprecated.
The visibility of this will be reduced, use FileCacheStoreConfig.location(String)
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
setLockAcquisitionTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
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.
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
setMachineId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.machineId(String) instead
setMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
setMarshaller(StreamingMarshaller) - Method in class org.infinispan.loaders.keymappers.MarshalledValueOrPrimitiveMapper
 
setMarshaller(StreamingMarshaller) - Method in interface org.infinispan.loaders.keymappers.MarshallingTwoWayKey2StringMapper
 
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
setMarshallVersion(short) - Method in class org.infinispan.config.GlobalConfiguration
setMarshallVersion(String) - Method in class org.infinispan.config.GlobalConfiguration
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
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
setMBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration
setMBeanServerLookupInstance(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
setMBeanServerLookupInstance(MBeanServerLookup) - Method in class org.infinispan.config.GlobalConfiguration
setMBeanServerProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
setMembers(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
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
 
setMissingLookedUpEntries(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(List<WriteCommand>) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
setModificationTime(long) - Method in class org.infinispan.io.GridFile.Metadata
 
setNetworkFuture(Future<T>) - 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<T>) - 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
 
setNewTopologyId(int) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setNewValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setNext(CommandInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Sets the next interceptor in the chain to the interceptor passed in.
setNodeName(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
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
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.
No longer used since 5.2, use HashConfigurationBuilder.numSegments(int) instead.
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.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.AbstractInvocationContext
 
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.CancelCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.control.LockControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.CreateCacheCommand
 
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.MapCombineCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.commands.read.ReduceCommand
 
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.statetransfer.StateRequestCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.xsite.XSiteAdminCommand
 
setParserContext(Class<? extends ConfigurationParser<?>>, ParserContext) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
setPassivation(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated.
The visibility of this method will be reduced. Use CacheLoaderManagerConfig.passivation(Boolean) instead.
setPendingCount(int) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
Sets the pending count to the given value.
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
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.GlobalJmxStatisticsType
Deprecated.
setProperties(TypedProperties) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
setProperties(Properties) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
setProperties(String) - Method in class org.infinispan.loaders.AbstractCacheLoaderConfig
 
setProperty(String, Object) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Defines a single value.
setProperty(String, String) - Static method in class org.infinispan.util.SysPropertyActions
 
setProperty(String, String) - Method in class org.infinispan.util.TypedProperties
 
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
setPurgeOnStartup(Boolean) - Method in class org.infinispan.loaders.decorators.AbstractDecoratorConfigurationBean
 
setPurgerThreads(Integer) - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
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
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
setRackId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.rackId(String) instead
setRawResult(T) - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
A method that result-bearing CountedCompleters may optionally use to help maintain result data.
setRawResult(V) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Forces the given value to be returned as a result.
setReadable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setReadable(boolean) - Method in class org.infinispan.io.GridFile
 
setReadOnly() - Method in class org.infinispan.io.GridFile
 
setRebalancingEnabled(boolean) - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
setRebalancingEnabled(boolean) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
setRebalancingEnabled(boolean) - Method in interface org.infinispan.topology.RebalancePolicy
 
setRecoveryManager(RecoveryManager) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
setReducePhaseDistributed(boolean) - Method in class org.infinispan.commands.read.MapCombineCommand
 
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
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
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
setRemote(boolean) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
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
 
setRemotelyFetchedValue(InternalCacheEntry) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
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
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
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
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
setReplQueueInterval(long, TimeUnit) - Method in class org.infinispan.config.Configuration
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
setReplTimeout(Long) - Method in class org.infinispan.config.Configuration.SyncType
Deprecated.
The visibility of this will be reduced, use Configuration.SyncType.replTimeout(Long)
setRetryWaitTimeIncreaseFactor(Integer) - Method in class org.infinispan.config.Configuration.StateRetrievalType
Deprecated.
The visibility of this will be reduced, use Configuration.StateRetrievalType.retryWaitTimeIncreaseFactor(Integer) instead
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.
setSeed(long) - Method in class org.infinispan.util.concurrent.jdk7backported.ThreadLocalRandom
Throws UnsupportedOperationException.
setShared(Boolean) - Method in class org.infinispan.config.CacheLoaderManagerConfig
Deprecated.
The visibility of this method will be reduced. Use CacheLoaderManagerConfig.shared(Boolean) instead.
setShutdownHookBehavior(GlobalConfiguration.ShutdownHookBehavior) - Method in class org.infinispan.config.GlobalConfiguration
setShutdownHookBehavior(String) - Method in class org.infinispan.config.GlobalConfiguration
setShutdownTimeout(Long) - Method in class org.infinispan.loaders.decorators.AsyncStoreConfig
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.
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
setSiteId(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.siteId(String) instead
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
 
setStateRetrievalChunkSize(int) - Method in class org.infinispan.config.Configuration
setStateRetrievalInitialRetryWaitTime(long) - Method in class org.infinispan.config.Configuration
setStateRetrievalInitialRetryWaitTime(long, TimeUnit) - Method in class org.infinispan.config.Configuration
setStateRetrievalLogFlushTimeout(long) - Method in class org.infinispan.config.Configuration
setStateRetrievalLogFlushTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
setStateRetrievalMaxNonProgressingLogWrites(int) - Method in class org.infinispan.config.Configuration
setStateRetrievalNumRetries(int) - Method in class org.infinispan.config.Configuration
setStateRetrievalRetryWaitTimeIncreaseFactor(int) - Method in class org.infinispan.config.Configuration
setStateRetrievalTimeout(long) - Method in class org.infinispan.config.Configuration
setStateRetrievalTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.TxInterceptor
Deprecated.
Use the statisticsEnabled attribute instead.
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
Deprecated.
We already have an attribute, we shouldn't have an operation for the same thing.
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
setStrictPeerToPeer(boolean) - Method in class org.infinispan.config.GlobalConfiguration
setStrictPeerToPeer(Boolean) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.strictPeerToPeer(Boolean) instead
setSubgroupsMerged(List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setSyncCommitPhase(boolean) - Method in class org.infinispan.config.Configuration
setSyncCommitPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
The visibility of this will be reduced, use Configuration.TransactionType.syncCommitPhase(Boolean) instead
setSyncReplTimeout(long) - Method in class org.infinispan.config.Configuration
setSyncReplTimeout(long, TimeUnit) - Method in class org.infinispan.config.Configuration
setSyncRollbackPhase(boolean) - Method in class org.infinispan.config.Configuration
setSyncRollbackPhase(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
The visibility of this will be reduced, use Configuration.TransactionType.setSyncRollbackPhase(Boolean) instead
setTakeOfflineAfterFailures(String, int) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
setTakeOfflineMinTimeToWait(String, long) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
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
setThreadContextClassLoader(Class) - Static method in class org.infinispan.util.SysPropertyActions
 
setThreadContextClassLoader(ClassLoader) - Static method in class org.infinispan.util.SysPropertyActions
 
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
setTopologyId(int) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
setTopologyId(int) - Method in interface org.infinispan.commands.TopologyAffectedCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
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
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration
setTransactionManagerLookupClass(String) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
The visibility of this will be reduced, use Configuration.TransactionType.transactionManagerLookupClass(Class) instead
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
setTransportClass(String) - Method in class org.infinispan.config.GlobalConfiguration.TransportType
Deprecated.
The visibility of this will be reduced, use GlobalConfiguration.TransportType.transportClass(Class) instead
setTransportNodeName(String) - Method in class org.infinispan.config.GlobalConfiguration
setTransportProperties(Properties) - Method in class org.infinispan.config.GlobalConfiguration
setTransportProperties(String) - Method in class org.infinispan.config.GlobalConfiguration
setType(Event.Type) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
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
setup(EmbeddedCacheManager) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
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, StateProvider, StateConsumer, LockManager, InternalEntryFactory, MapReduceManager, StateTransferManager, BackupSender, CancellationService) - 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
setUseEagerLocking(boolean) - Method in class org.infinispan.config.Configuration
setUseEagerLocking(Boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
The visibility of this will be reduced, use Configuration.TransactionType.useEagerLocking(Boolean) instead
setUseLazyDeserialization(boolean) - Method in class org.infinispan.config.Configuration
Deprecated.
Use AbstractFluentConfigurationBean.storeAsBinary() instead
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
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
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
 
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
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
 
setWakeUpInterval(Long) - Method in class org.infinispan.config.Configuration.EvictionType
setWritable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setWritable(boolean) - Method in class org.infinispan.io.GridFile
 
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
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
 
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.
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.remote.ClusteredGetCommand
 
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) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
shouldInvokeRemoteTxCommand(TxInvocationContext) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
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.jdk8backported.ForkJoinPool
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
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.jdk8backported.ForkJoinPool
Possibly attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
shutdownNow() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
shutdownTimeout() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
Timeout to stop the cache store.
shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
Timeout to stop the cache store.
shutdownTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
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.
SIMPLE_CLUSTERED_VERSION - Static variable in interface org.infinispan.marshall.Ids
 
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.TopologyIdUpdater - Class in org.infinispan.container.versioning
 
SimpleClusteredVersionGenerator.TopologyIdUpdater() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
 
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
 
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.AbstractStoreConfiguration
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.AbstractStoreConfigurationBuilder
 
singletonStore() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
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.AbstractStoreConfigurationChildBuilder
 
singletonStore() - Method in interface org.infinispan.configuration.cache.CacheStoreConfiguration
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 interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
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.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<S> - 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.
site() - Method in class org.infinispan.configuration.cache.BackupConfiguration
Returns the name of the site where this cache backups its data.
site(String) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
site() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
site() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
site() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
SiteConfiguration - Class in org.infinispan.configuration.global
 
SiteConfigurationBuilder - Class in org.infinispan.configuration.global
 
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.
sites() - Method in class org.infinispan.configuration.cache.Configuration
 
sites() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
sites() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
sites() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
SitesConfiguration - Class in org.infinispan.configuration.cache
 
SitesConfiguration(List<BackupConfiguration>, BackupForConfiguration, boolean, Set<String>) - Constructor for class org.infinispan.configuration.cache.SitesConfiguration
 
SitesConfigurationBuilder - Class in org.infinispan.configuration.cache
 
SitesConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
siteStatus(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
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.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.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.InfinispanCollections.EmptyList
 
size() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
size() - Method in class org.infinispan.util.InfinispanCollections.EmptySet
 
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, FlagAffectedCommand) - 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.CacheStoreInterceptor
 
skip(InvocationContext, FlagAffectedCommand) - 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(InvocationContext) - Method in class org.infinispan.interceptors.DistCacheStoreInterceptor
 
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
 
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.
SocketBinding - Class in org.infinispan.configuration.as
SocketBinding.
SocketBinding(String, InetAddress, int) - Constructor for class org.infinispan.configuration.as.SocketBinding
 
SocketBindingGroup - Class in org.infinispan.configuration.as
 
SocketBindingGroup(String, String, int) - Constructor for class org.infinispan.configuration.as.SocketBindingGroup
 
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
 
SourceMigrator - Interface in org.infinispan.upgrade
Performs migration operations on the source server or cluster of servers
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(long, TimeUnit) - 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
 
spliterator() - Method in class org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.KeySetView
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in interface org.infinispan.util.logging.Log
 
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.commands.CommandsFactoryImpl
 
start() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
start() - Method in class org.infinispan.context.TransactionalInvocationContextContainer
 
start() - Method in class org.infinispan.distribution.L1ManagerImpl
 
start() - Method in class org.infinispan.eviction.ActivationManagerImpl
 
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.ActivationInterceptor
 
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.distribution.L1NonTxInterceptor
 
start() - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
start() - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
start() - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
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.interceptors.ReplicationInterceptor
 
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 interface org.infinispan.loaders.CacheLoader
 
start() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
start() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
start() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
start() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
start() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
start() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
start() - Method in class org.infinispan.loaders.file.FileCacheStore
 
start() - Method in class org.infinispan.loaders.LockSupportCacheStore
 
start() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
start() - Method in class org.infinispan.manager.DefaultCacheManager
 
start() - Method in class org.infinispan.marshall.CacheMarshaller
 
start() - Method in class org.infinispan.marshall.GlobalMarshaller
 
start() - Method in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
start() - Method in class org.infinispan.marshall.jboss.ExternalizerTable
 
start() - Method in class org.infinispan.marshall.jboss.JBossMarshaller
 
start() - Method in interface org.infinispan.marshall.StreamingMarshaller
 
start() - Method in class org.infinispan.marshall.VersionAwareMarshaller
 
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() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
start() - Method in interface org.infinispan.statetransfer.StateProvider
 
start() - Method in class org.infinispan.statetransfer.StateProviderImpl
 
start() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
start() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
start() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
start() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
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.xsite.BackupReceiverRepositoryImpl
 
start() - Method in class org.infinispan.xsite.BackupSenderImpl
 
startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
startBatch() - Method in class org.infinispan.AbstractDelegatingCache
 
startBatch() - Method in class org.infinispan.batch.BatchContainer
Starts a batch
startBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
startBatch() - Method in interface org.infinispan.Cache
Starts a batch.
startBatch() - Method in class org.infinispan.CacheImpl
 
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.
startOutboundTransfer(Address, int, Set<Integer>) - Method in interface org.infinispan.statetransfer.StateProvider
Start to send cache entries that belong to the given set of segments.
startOutboundTransfer(Address, int, Set<Integer>) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
startPrefixMapping(String, String) - Method in class org.infinispan.config.parsing.NamespaceFilter
 
startRebalance(CacheTopology) - Method in class org.infinispan.topology.ClusterCacheStatus
 
state - Variable in class org.infinispan.factories.AbstractComponentRegistry
 
STATE_CHUNK - Static variable in interface org.infinispan.marshall.Ids
 
StateChangingEntry - Interface in org.infinispan.container.entries
An entry that may have state, such as created, changed, valid, etc.
StateChunk - Class in org.infinispan.statetransfer
Encapsulates a chunk of cache entries that belong to the same segment.
StateChunk(int, Collection<InternalCacheEntry>, boolean) - Constructor for class org.infinispan.statetransfer.StateChunk
 
StateChunk.Externalizer - Class in org.infinispan.statetransfer
 
StateChunk.Externalizer() - Constructor for class org.infinispan.statetransfer.StateChunk.Externalizer
 
StateConsumer - Interface in org.infinispan.statetransfer
Handles inbound state transfers.
StateConsumerImpl - Class in org.infinispan.statetransfer
StateConsumer implementation.
StateConsumerImpl() - Constructor for class org.infinispan.statetransfer.StateConsumerImpl
 
StateProvider - Interface in org.infinispan.statetransfer
Handles outbound state transfers.
StateProviderImpl - Class in org.infinispan.statetransfer
StateProvider implementation.
StateProviderImpl() - Constructor for class org.infinispan.statetransfer.StateProviderImpl
 
StateRequestCommand - Class in org.infinispan.statetransfer
This command is used by a StateConsumer to request transactions and cache entries from a StateProvider.
StateRequestCommand(String) - Constructor for class org.infinispan.statetransfer.StateRequestCommand
 
StateRequestCommand(String, StateRequestCommand.Type, Address, int, Set<Integer>) - Constructor for class org.infinispan.statetransfer.StateRequestCommand
 
StateRequestCommand.Type - Enum in org.infinispan.statetransfer
 
StateResponseCommand - Class in org.infinispan.statetransfer
This command is used by a StateProvider to push cache entries to a StateConsumer.
StateResponseCommand(String) - Constructor for class org.infinispan.statetransfer.StateResponseCommand
 
StateResponseCommand(String, Address, int, Collection<StateChunk>) - Constructor for class org.infinispan.statetransfer.StateResponseCommand
 
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.
StateTransferComponentFactory - Class in org.infinispan.factories
StateTransferComponentFactory() - Constructor for class org.infinispan.factories.StateTransferComponentFactory
 
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.
StateTransferInterceptor - Class in org.infinispan.statetransfer
This interceptor has two tasks: If the command's topology id is higher than the current topology id, wait for the node to receive transaction data for the new topology id. If the topology id changed during a command's execution, forward the command to the new owners. Note that we don't keep track of old cache topologies (yet), so we actually forward the command to all the owners -- not just the ones added in the new topology.
StateTransferInterceptor() - Constructor for class org.infinispan.statetransfer.StateTransferInterceptor
 
StateTransferLock - Interface in org.infinispan.statetransfer
We use the state transfer lock for three different things: We don't want to execute a command until we have the transaction table for that topology id.
StateTransferLockImpl - Class in org.infinispan.statetransfer
StateTransferLock implementation.
StateTransferLockImpl() - Constructor for class org.infinispan.statetransfer.StateTransferLockImpl
 
stateTransferManager - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
StateTransferManager - Interface in org.infinispan.statetransfer
A component that manages the state transfer when the topology of the cluster changes.
StateTransferManagerImpl - Class in org.infinispan.statetransfer
StateTransferManager implementation.
StateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.StateTransferManagerImpl
 
Stats - Interface in org.infinispan.stats
Stats.
StatsImpl - Class in org.infinispan.stats
StatsImpl.
StatsImpl(InterceptorChain) - Constructor for class org.infinispan.stats.StatsImpl
 
status() - Method in interface org.infinispan.xsite.BackupSender
Returns a Map having as entries the site names and as value Boolean.TRUE if the site is online and Boolean.FALSE if it is offline.
status() - Method in class org.infinispan.xsite.BackupSenderImpl
 
status() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
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.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 interface org.infinispan.loaders.CacheLoader
 
stop() - Method in class org.infinispan.loaders.CacheLoaderManagerImpl
 
stop() - Method in class org.infinispan.loaders.cluster.ClusterCacheLoader
 
stop() - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
stop() - Method in class org.infinispan.loaders.decorators.AsyncStore
 
stop() - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
stop() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
stop() - Method in class org.infinispan.loaders.file.FileCacheStore
 
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.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 interface org.infinispan.statetransfer.StateConsumer
Cancels all incoming state transfers.
stop() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
stop() - Method in interface org.infinispan.statetransfer.StateProvider
Cancels all outbound state transfers.
stop() - Method in class org.infinispan.statetransfer.StateProviderImpl
 
stop() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
stop() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
stop() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
stop() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
stop() - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
stopApplyingState() - Method in interface org.infinispan.statetransfer.StateConsumer
Stops applying incoming state.
stopApplyingState() - Method in class org.infinispan.statetransfer.StateConsumerImpl
Stops applying incoming state.
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 interface org.infinispan.loaders.CacheStore
Stores an entry
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.AsyncStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.ReadOnlyStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.decorators.SingletonStore
 
store(InternalCacheEntry) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
Store - Class in org.infinispan.loaders.modifications
Store(InternalCacheEntry) - Constructor for class org.infinispan.loaders.modifications.Store
 
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.
StoreConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
 
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, L) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
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.BackupConfiguration
How does the backup happen: sync or async.
strategy(BackupConfiguration.BackupStrategy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Sets the strategy used for backing up data: sync or async.
strategy() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
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.
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.
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
 
stringToElement(String) - Static method in class org.infinispan.config.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
StripedLock - Class in org.infinispan.util.concurrent.locks
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
StripedLock() - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
This constructor just calls StripedLock.StripedLock(int) with a default concurrency value of 20.
StripedLock(int) - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
subList(int, int) - Method in class org.infinispan.util.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(Address, Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submit(Address, DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submit(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submit(DistributedTask<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(Address, Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given Callable task for execution on the specified target Infinispan node.
submit(Address, DistributedTask<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given DistributedTask for execution on the specified target Infinispan node.
submit(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given Callable task for execution on a single Infinispan node.
submit(DistributedTask<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given DistributedTask for 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
 
submit(ForkJoinTask<T>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
Submits a ForkJoinTask for execution.
submit(Callable<T>) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
submit(Runnable, T) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
submit(Runnable) - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinPool
 
submitEverywhere(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submitEverywhere(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submitEverywhere(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submitEverywhere(DistributedTask<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 execution on all available Infinispan nodes.
submitEverywhere(DistributedTask<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given DistributedTask for execution on all available Infinispan nodes.
submitEverywhere(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given Callable task for execution on all available Infinispan nodes using input keys specified by K input.
submitEverywhere(DistributedTask<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Submits the given DistributedTask for execution on all available Infinispan nodes using input keys specified by K input.
SUCCESS - Static variable in class org.infinispan.xsite.XSiteAdminOperations
 
SUCCESSFUL_EMPTY_RESPONSE - Static variable in class org.infinispan.remoting.responses.SuccessfulResponse
 
SUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.marshall.Ids
 
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().
supportsConcurrentUpdates() - Method in class org.infinispan.configuration.cache.LockingConfiguration
This option applies to non-transactional caches only (both clustered and local): if set to true(default value) the cache keeps data consistent in the case of concurrent updates.
supportsConcurrentUpdates(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
supportsMultiThreadedPurge() - Method in class org.infinispan.loaders.AbstractCacheStore
 
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.
swapPrimaryOwnersWithBackups(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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
 
SYNC_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.Ids
 
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
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.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
 
SyncConsistentHashFactory - Class in org.infinispan.distribution.ch
A ConsistentHashFactory implementation that guarantees caches with the same members have the same consistent hash.
SyncConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
SyncConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch
 
SyncConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch
 
SyncConsistentHashFactory.Externalizer() - Constructor for class org.infinispan.distribution.ch.SyncConsistentHashFactory.Externalizer
 
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
 
synchronizeData(String) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
synchronizeData(Cache<Object, Object>) - Method in interface org.infinispan.upgrade.TargetMigrator
Performs the synchronization of data between source and target by retrieving the set of known keys and fetching each key in turn
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
Privileged actions for the package
SysPropertyActions() - Constructor for class org.infinispan.util.SysPropertyActions
 

T

take() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
takeExecutorOwnership - Variable in class org.infinispan.distexec.DefaultExecutorService
 
takeOffline() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
takeOffline() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
TakeOfflineConfiguration - Class in org.infinispan.configuration.cache
 
TakeOfflineConfiguration(int, long) - Constructor for class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
TakeOfflineConfigurationBuilder - Class in org.infinispan.configuration.cache
 
TakeOfflineConfigurationBuilder(ConfigurationBuilder, BackupConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
takeSiteOffline(String) - Method in interface org.infinispan.xsite.BackupSender
 
takeSiteOffline(String) - Method in class org.infinispan.xsite.BackupSenderImpl
 
takeSiteOffline(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
target - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
TargetMigrator - Interface in org.infinispan.upgrade
Performs migration operations on the target server or cluster of servers
taskId - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
terminate() - Method in class org.infinispan.statetransfer.InboundTransferTask
Terminate abruptly regardless if the segments were received or not.
TestDelayFactory - Class in org.infinispan.factories
Internal class, only used for testing.
TestDelayFactory() - Constructor for class org.infinispan.factories.TestDelayFactory
 
TestDelayFactory.Component - Class in org.infinispan.factories
 
TestDelayFactory.Component() - Constructor for class org.infinispan.factories.TestDelayFactory.Component
 
testImmutability(String) - Method in class org.infinispan.config.AbstractConfigurationBean
Checks field modifications via setters
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
 
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.AsyncStoreConfiguration
Size of the thread pool whose threads are responsible for applying the modifications.
threadPoolSize(int) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
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.
throwStackAwareConfigurationException(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
 
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.
timeout(long, TimeUnit) - 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.
timeout() - Method in interface org.infinispan.distexec.DistributedTask
Returns timeout for the execution of this task
timeout(long, TimeUnit) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
Provide DistributedTask task timeout
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
 
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
 
TOPOLOGY_AWARE_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.Ids
 
TOPOLOGY_AWARE_SYNC_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.Ids
 
TopologyAffectedCommand - Interface in org.infinispan.commands
Some of the commands sent over the wire can only be honored by the receiver if the topology of the cluster at delivery time is still 'compatible' with the topology in place at send time (eg.
TopologyAwareAddress - Interface in org.infinispan.remoting.transport
Wraps a TopologyUUID JGroups address
TopologyAwareConsistentHashFactory - Class in org.infinispan.distribution.ch
Default topology-aware consistent hash factory implementation.
TopologyAwareConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory
 
TopologyAwareConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch
 
TopologyAwareConsistentHashFactory.Externalizer() - Constructor for class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory.Externalizer
 
TopologyAwareSyncConsistentHashFactory - Class in org.infinispan.distribution.ch
A ConsistentHashFactory implementation that guarantees caches with the same members have the same consistent hash and also tries to distribute segments based on the topology information in TransportConfiguration.
TopologyAwareSyncConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory
 
TopologyAwareSyncConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch
 
TopologyAwareSyncConsistentHashFactory.Externalizer() - Constructor for class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory.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.transaction.AbstractCacheTransaction
 
TopologyInfo - Class in org.infinispan.distribution.topologyaware
This class holds the topology hierarchy of a cache's members.
TopologyInfo(Collection<Address>) - Constructor for class org.infinispan.distribution.topologyaware.TopologyInfo
 
TopologyLevel - Enum in org.infinispan.distribution.topologyaware
The cluster topology is a tree with five levels: the entire cluster, sites, racks, machines, and individual nodes.
toStream(ObjectOutput) - Method in interface org.infinispan.loaders.CacheStore
Loads the entire state into a stream, using whichever format is most efficient for the cache loader implementation.
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.decorators.ChainingCacheStore
 
toStream(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.file.FileCacheStore
 
toStreamLockSafe(ObjectOutput) - Method in class org.infinispan.loaders.LockSupportCacheStore
 
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.ClearOperation
 
toString() - Method in class org.infinispan.atomic.DeltaCompositeKey
 
toString() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
toString() - Method in class org.infinispan.atomic.PutOperation
 
toString() - Method in class org.infinispan.atomic.RemoveOperation
 
toString() - Method in class org.infinispan.CacheImpl
 
toString() - Method in class org.infinispan.commands.CancelCommand
 
toString() - Method in class org.infinispan.commands.control.LockControlCommand
 
toString() - Method in class org.infinispan.commands.CreateCacheCommand
 
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.MapCombineCommand
 
toString() - Method in class org.infinispan.commands.read.ReduceCommand
 
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.commands.write.VersionedPutKeyValueCommand
 
toString() - Method in class org.infinispan.commons.hash.MurmurHash2
 
toString() - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
toString() - Method in class org.infinispan.commons.hash.MurmurHash3
 
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 enum org.infinispan.configuration.as.Mode
 
toString() - Method in class org.infinispan.configuration.as.NetworkInterface
 
toString() - Method in class org.infinispan.configuration.as.OutboundSocketBinding
 
toString() - Method in class org.infinispan.configuration.as.SocketBindingGroup
 
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.AsyncStoreConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
toString() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfiguration
 
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.LegacyLoaderConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.LegacyStoreConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.LegacyStoreConfigurationBuilder
 
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.SitesConfiguration
 
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.TakeOfflineConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
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.SiteConfiguration
 
toString() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
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.distexec.mapreduce.MapReduceManagerImpl.IntermediateCompositeKey
 
toString() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
toString() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
toString() - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
toString() - Method in class org.infinispan.distribution.group.GroupingConsistentHash
 
toString() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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.JmxOperationParameter
 
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.io.GridFile
 
toString() - Method in enum org.infinispan.jmx.annotations.DataType
 
toString() - Method in enum org.infinispan.jmx.annotations.DisplayType
 
toString() - Method in enum org.infinispan.jmx.annotations.Units
 
toString() - Method in class org.infinispan.loaders.AbstractCacheStoreConfig
 
toString() - Method in class org.infinispan.loaders.bucket.Bucket
 
toString() - Method in class org.infinispan.loaders.decorators.SingletonStore
 
toString() - Method in class org.infinispan.loaders.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.manager.DefaultCacheManager
 
toString() - Method in class org.infinispan.marshall.MarshalledValue
 
toString() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
toString() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
toString() - Method in 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.AggregateBackupResponse
 
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.remoting.transport.jgroups.JGroupsBackupResponse
 
toString() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
toString() - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
toString() - Method in class org.infinispan.statetransfer.StateChunk
 
toString() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
toString() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
toString() - Method in class org.infinispan.statetransfer.TransactionInfo
 
toString() - Method in class org.infinispan.topology.CacheJoinInfo
 
toString() - Method in class org.infinispan.topology.CacheTopology
 
toString() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
toString() - Method in class org.infinispan.topology.ClusterCacheStatus
 
toString() - Method in class org.infinispan.transaction.LocalTransaction
 
toString() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
toString() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
toString() - Method in class org.infinispan.transaction.lookup.JBossTransactionManagerLookup
 
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.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.ForkJoinPool
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
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.AbstractPerEntryLockContainer
 
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.locks.OwnableRefCountingReentrantLock
 
toString() - Method in class org.infinispan.util.concurrent.locks.VisibleOwnerRefCountingReentrantLock
 
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
 
toString() - Method in exception org.infinispan.xsite.BackupFailureException
 
toString() - Method in class org.infinispan.xsite.OfflineStatus
 
toString() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
toString() - Method in class org.infinispan.xsite.XSiteBackup
 
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
 
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
 
toURI() - Method in class org.infinispan.io.GridFile
 
toURL() - Method in class org.infinispan.io.GridFile
 
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 - Static variable in class org.infinispan.marshall.jboss.AbstractJBossMarshaller
 
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_INFO - 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.
TransactionalInvocationContextContainer - Class in org.infinispan.context
Invocation context to be used for transactional caches.
TransactionalInvocationContextContainer() - Constructor for class org.infinispan.context.TransactionalInvocationContextContainer
 
TransactionBoundaryCommand - Interface in org.infinispan.commands.tx
An transaction boundary command that allows the retrieval of an attached GlobalTransaction
TransactionCompleted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and the transaction completes, either with a commit or a rollback.
TransactionCompletedEvent<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
 
TransactionInfo - Class in org.infinispan.statetransfer
A representation of a transaction that is suitable for transferring between a StateProvider and a StateConsumer running on different members of the same cache.
TransactionInfo(GlobalTransaction, int, WriteCommand[], Set<Object>) - Constructor for class org.infinispan.statetransfer.TransactionInfo
 
TransactionInfo.Externalizer - Class in org.infinispan.statetransfer
 
TransactionInfo.Externalizer() - Constructor for class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
transactionManager - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
transactionManager - Variable in class org.infinispan.CacheImpl
 
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.TransactionConfiguration
 
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 - Enum in org.infinispan.configuration.as
 
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.
TransactionRegisteredEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event is passed in to any method annotated with TransactionRegistered.
transactionRemotelyPrepared(TxInvocationContext) - Static method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
transactionsRequestedByNodeWithOlderTopology(Address, int, int) - Method in interface org.infinispan.util.logging.Log
 
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
 
TransactionSynchronizerInterceptor - Class in org.infinispan.statetransfer
With the Non-Blocking State Transfer (NBST) in place it is possible for a transactional command to be forwarded multiple times, concurrently to the same node.
TransactionSynchronizerInterceptor() - Constructor for class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
 
transactionTable - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
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, String) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
TransactionXaAdapter(TransactionTable, RecoveryManager, TransactionCoordinator, CommandsFactory, RpcManager, ClusteringDependentLogic, Configuration, String) - 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
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
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() - 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.
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.
TransportFactory - Class in org.infinispan.factories
Factory for Transport implementations
TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
 
triggerRebalance(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
Used by RebalancePolicy to start a state transfer.
triggerRebalance(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
tryAcquire(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
tryAdvance(ConcurrentHashMapV8.Action<? super T>) - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
If an element remains, applies the action and returns true.
tryComplete() - Method in class org.infinispan.util.concurrent.jdk8backported.CountedCompleter
If the pending count is nonzero, decrements the count; otherwise invokes CountedCompleter.onCompletion(org.infinispan.util.concurrent.jdk8backported.CountedCompleter) and then similarly tries to complete this task's completer, if one exists, else marks this task as complete.
tryingToBringOnlineNonexistentSite(String) - Method in interface org.infinispan.util.logging.Log
 
tryLock(L, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.AbstractLockContainer
 
tryLock(OwnableRefCountingReentrantLock, 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(VisibleOwnerRefCountingReentrantLock, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
tryLock(VisibleOwnerReentrantLock, 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
 
trySplit() - Method in interface org.infinispan.util.concurrent.jdk8backported.ConcurrentHashMapV8.ConcurrentHashMapSpliterator
If possible, returns a new spliterator covering approximately one half of the elements, which will not be covered by this spliterator.
tryUnfork() - Method in class org.infinispan.util.concurrent.jdk8backported.ForkJoinTask
Tries to unschedule this task for execution.
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
 
TxDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Handles the distribution of the transactional caches.
TxDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.
txTable - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
txTable - Variable in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
txTable - Variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
txTable() - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
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
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToInt(String, int) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToLong(String, long) - Method in interface org.infinispan.util.logging.Log
 
unableToCopyEntryForUpdate(Object) - Method in interface org.infinispan.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
 
unableToLoadClass(String, String, Throwable) - 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
 
unableToReadVersionId() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterCacheManagerMBeans() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterMBeans() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterMBeans(String) - Method in interface org.infinispan.util.logging.Log
 
unableToRemoveEntryAfterActivation(Object, 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
 
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
 
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
 
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
 
undelegateCacheLoader(CacheLoader) - Static method in class org.infinispan.loaders.decorators.AbstractDelegatingStore
 
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.
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
 
unfinishedTransactionsRemain(int, int) - Method in interface org.infinispan.util.logging.Log
 
union(CH, CH) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Creates a union of two compatible ConsistentHashes (use the same hashing function and have the same configuration parameters).
union(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
Merges two consistent hash objects that have the same number of segments, numOwners and hash function.
union(DefaultConsistentHash, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
Merges two consistent hash objects that have the same number of segments, numOwners and hash function.
union(ReplicatedConsistentHash, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
union(DefaultConsistentHash, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
Units - Enum in org.infinispan.jmx.annotations
 
unknownMigrator(String) - Method in interface org.infinispan.util.logging.Log
 
unknownResponsesFromRemoteCache(Collection<Response>) - Method in interface org.infinispan.util.logging.Log
 
unlock(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
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(OwnableRefCountingReentrantLock, 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(VisibleOwnerRefCountingReentrantLock, Object) - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantPerEntryLockContainer
 
unlock(VisibleOwnerReentrantLock, 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
 
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
 
unregister(UUID) - Method in interface org.infinispan.commands.CancellationService
Unregisters thread with CancellationService given an id
unregister(UUID) - Method in class org.infinispan.commands.CancellationServiceImpl
 
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().
unregisterMBeans(String, MBeanServer) - Static method in class org.infinispan.jmx.JmxUtil
Unregister all mbeans whose object names match a given filter.
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 BasicCache.put(Object, Object) and BasicCache.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 BasicCache.put(Object, Object) and BasicCache.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
 
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
 
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
 
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
 
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.file.FileCacheStore
 
updateCacheStatus(String, ClusterCacheStatus) - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
updateCacheStatus(String, ClusterCacheStatus) - Method in interface org.infinispan.topology.RebalancePolicy
Called when the status of a cache changes.
updateCacheStatusAfterMerge(String, List<Address>, List<CacheTopology>) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
updateCacheTopology(CacheTopology) - Method in class org.infinispan.topology.ClusterCacheStatus
 
updateClusterMembers(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
updateClusterMembers(List<Address>) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
updateConsistentHash(CacheTopology) - Method in interface org.infinispan.topology.CacheTopologyHandler
Invoked when the CH has to be immediately updated because of a leave or when the state transfer has completed and we have to install a permanent CH (pendingCH == null).
updateDomain(ComponentsJmxRegistration, GlobalComponentRegistry, MBeanServer, String) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
updateDomain(ComponentsJmxRegistration, MBeanServer, String) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
updateMembers(CH, List<Address>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Create a new consistent hash instance, based on an existing instance, but with a new list of members.
updateMembers(DefaultConsistentHash, List<Address>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
Leavers are removed and segments without owners are assigned new owners.
updateMembers(ReplicatedConsistentHash, List<Address>) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
updateMembers(DefaultConsistentHash, List<Address>) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
updateOnCommunicationFailure(long) - Method in class org.infinispan.xsite.OfflineStatus
 
updateRebalanceMembersList() - Method in class org.infinispan.topology.ClusterCacheStatus
Should be called after the members list was updated in any other way (ClusterCacheStatus.removeMember(Address), ClusterCacheStatus.updateClusterMembers(java.util.List) etc.)
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
 
URN_JBOSS_DOMAIN - Static variable in class org.infinispan.configuration.as.ParserAS7
 
URN_JBOSS_DOMAIN_INFINISPAN - Static variable in class org.infinispan.configuration.as.ParserAS7
 
use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.config.Configuration.RecoveryType
Deprecated.
 
use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.config.Configuration.TransactionType
Deprecated.
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.
useIntermediatePerTaskCache() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
useIntermediateSharedCache - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
useIntermediateSharedCache() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
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.
useTwoPhaseCommit(boolean) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Configures whether the replication happens in a 1PC or 2PC for sync backups.
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 interface org.infinispan.configuration.Builder
Validate the data in this builder before building the configuration bean
validate() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
validate() - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.FileCacheStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.LegacyLoaderConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.LoadersConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
VALIDATING_SYSTEM_PROPERTY - Static variable in class org.infinispan.config.InfinispanConfiguration
Deprecated.
 
ValidResponse - Class in org.infinispan.remoting.responses
A valid response
ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
 
value - Variable in class org.infinispan.commands.write.RemoveCommand
When not null, value indicates that the entry should only be removed if the key is mapped to this value.
value - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
value - Variable in class org.infinispan.container.entries.ImmortalCacheValue
 
value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
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.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.as.Attribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.as.Element
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.as.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.as.TransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.BackupFailurePolicy
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.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.distexec.DistributedTaskExecutionPolicy
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.distribution.topologyaware.TopologyLevel
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.jmx.annotations.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.jmx.annotations.DisplayType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.jmx.annotations.MeasurementType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.jmx.annotations.Units
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.modifications.Modification.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.statetransfer.StateRequestCommand.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.topology.CacheTopologyControlCommand.Type
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.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.
valueOf(String) - Static method in enum org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.xsite.XSiteAdminCommand.AdminOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.xsite.XSiteAdminCommand.Status
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.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.as.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.as.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.as.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.as.TransactionMode
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.BackupConfiguration.BackupStrategy
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.BackupFailurePolicy
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() - 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() - Method in class org.infinispan.DecoratedCache
 
values() - Static method in enum org.infinispan.distexec.DistributedTaskExecutionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
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.distribution.topologyaware.TopologyLevel
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.jmx.annotations.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.jmx.annotations.DisplayType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.jmx.annotations.MeasurementType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.jmx.annotations.Units
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.modifications.Modification.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.rpc.ResponseMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.statetransfer.StateRequestCommand.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.topology.CacheTopologyControlCommand.Type
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 - 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
 
values() - Method in class org.infinispan.util.InfinispanCollections.EmptyMap
 
values() - Static method in enum org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.xsite.XSiteAdminCommand.AdminOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.xsite.XSiteAdminCommand.Status
Returns an array containing the constants of this enum type, in the order they are declared.
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.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_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.distribution
A version of the TxDistributionInterceptor that adds logic to handling prepares when entries are versioned.
VersionedDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.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
 
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
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
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
 
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).
ViewChangedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with ViewChanged.
VisibleOwnerReentrantLock - Class in org.infinispan.util.concurrent.locks
Extends ReentrantLock only to make the VisibleOwnerReentrantLock.getOwner() method public.
VisibleOwnerReentrantLock() - Constructor for class org.infinispan.util.concurrent.locks.VisibleOwnerReentrantLock
 
VisibleOwnerRefCountingReentrantLock - Class in org.infinispan.util.concurrent.locks
A version of VisibleOwnerReentrantLock that has a reference counter, and implements RefCountingLock.
VisibleOwnerRefCountingReentrantLock() - Constructor for class org.infinispan.util.concurrent.locks.VisibleOwnerRefCountingReentrantLock
 
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.CacheLoaderInterceptor
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.interceptors.CacheStoreInterceptor.StoreModificationsBuilder
 
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
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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.distribution.NonTxDistributionInterceptor
Don't forward in the case of clear commands, just acquire local locks and broadcast.
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.NonTransactionalLockingInterceptor
 
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.TxInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.xsite.PessimisticBackupInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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<V>) - Method in class org.infinispan.commands.AbstractVisitor
 
visitDistributedExecuteCommand(InvocationContext, DistributedExecuteCommand<V>) - 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.BatchingInterceptor
 
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
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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.CallInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.ReplicationInterceptor
 
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
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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.CallInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
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.ReplicationInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.TxInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
 
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
 
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.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.xsite.PessimisticBackupInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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.distribution.L1NonTxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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.distribution.BaseDistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.NonTxConcurrentDistributionInterceptor
 
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.TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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.distribution.BaseDistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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.distribution.BaseDistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.xsite.BackupReceiverImpl.BackupCacheUpdater
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
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

waitForBackupToFinish() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
waitForBackupToFinish() - Method in interface org.infinispan.remoting.transport.BackupResponse
 
waitForBackupToFinish() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
waitForCacheToStart(String) - Method in interface org.infinispan.util.logging.Log
 
waitForChannelToConnect() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
waitForInitialStateTransferToComplete() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
waitForLockRelease(Object, long) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
waitForLockRelease(Object, long) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Checks if this transaction holds a lock on the given key and then waits until the transaction completes or until the timeout expires and returns true if the transaction is complete or false otherwise.
waitForTopology(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
waitForTopology(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
waitForTransactionData(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
waitForTransactionData(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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.
wakeUpInterval(long, TimeUnit) - 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
 
warnXsiteBackupFailed(String, String, Object) - Method in interface org.infinispan.util.logging.Log
 
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.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
These properties are passed directly to the cache store.
withProperties(Properties) - Method in class org.infinispan.configuration.cache.AbstractLoaderConfigurationChildBuilder
 
withProperties(Properties) - Method in class org.infinispan.configuration.cache.ClusterCacheLoaderConfigurationBuilder
 
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.LegacyLoaderConfigurationBuilder
These properties are passed directly to the cache loader.
withProperties(Properties) - Method in interface org.infinispan.configuration.cache.LoaderConfigurationChildBuilder
Properties passed to the cache store or 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
wouldLose(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
wrap(AdvancedCache<K, V>) - Method in interface org.infinispan.AbstractDelegatingAdvancedCache.AdvancedCacheWrapper
 
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, FlagAffectedCommand) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for addition to cache.
wrapEntryForPut(InvocationContext, Object, InternalCacheEntry, boolean, FlagAffectedCommand) - 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
 
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.
writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
WriteCommand - Interface in org.infinispan.commands.write
A command that modifies the cache in some way
writeCommandHeader(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeCommandParameters(ObjectOutput, ReplicableCommand) - 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.util.ImmutableListCopy
Format: - entry array size (int) - elements (Object)
writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
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, DeltaCompositeKey) - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
 
writeObject(ObjectOutput, PutOperation) - Method in class org.infinispan.atomic.PutOperation.Externalizer
 
writeObject(ObjectOutput, RemoveOperation) - Method in class org.infinispan.atomic.RemoveOperation.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, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash.Externalizer
 
writeObject(ObjectOutput, DefaultConsistentHashFactory) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHash.Externalizer
 
writeObject(ObjectOutput, ReplicatedConsistentHashFactory) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, SyncConsistentHashFactory) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, TopologyAwareConsistentHashFactory) - Method in class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, TopologyAwareSyncConsistentHashFactory) - Method in class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory.Externalizer
 
writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeObject(ObjectOutput, Bucket) - Method in class org.infinispan.loaders.bucket.Bucket.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, CacheNotFoundResponse) - Method in class org.infinispan.remoting.responses.CacheNotFoundResponse.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, StateChunk) - Method in class org.infinispan.statetransfer.StateChunk.Externalizer
 
writeObject(ObjectOutput, TransactionInfo) - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
writeObject(ObjectOutput, CacheJoinInfo) - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
writeObject(ObjectOutput, CacheTopology) - Method in class org.infinispan.topology.CacheTopology.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, ByteArrayKey) - Method in class org.infinispan.util.ByteArrayKey.Externalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.util.Immutables.ImmutableMapWrapperExternalizer
 
writeObject(ObjectOutput, List) - Method in class org.infinispan.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
writeObject(ObjectOutput, Set) - Method in class org.infinispan.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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
 
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
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 

X

XaTransactionTable - Class in org.infinispan.transaction.xa
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.
XSiteAdminCommand - Class in org.infinispan.xsite
Command used for handling XSiteReplication administrative operations.
XSiteAdminCommand() - Constructor for class org.infinispan.xsite.XSiteAdminCommand
 
XSiteAdminCommand(String) - Constructor for class org.infinispan.xsite.XSiteAdminCommand
 
XSiteAdminCommand(String, String, XSiteAdminCommand.AdminOperation, Integer, Long) - Constructor for class org.infinispan.xsite.XSiteAdminCommand
 
XSiteAdminCommand.AdminOperation - Enum in org.infinispan.xsite
 
XSiteAdminCommand.Status - Enum in org.infinispan.xsite
 
XSiteAdminOperations - Class in org.infinispan.xsite
Managed bean exposing sys admin operations for Cross-Site replication functionality.
XSiteAdminOperations() - Constructor for class org.infinispan.xsite.XSiteAdminOperations
 
XSiteBackup - Class in org.infinispan.xsite
 
XSiteBackup(String, boolean, long) - Constructor for class org.infinispan.xsite.XSiteBackup
 

_

_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 _ 
Infinispan Core 5.2.11.Final-redhat-2

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