Skip navigation links
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

Abort - Class in org.infinispan.cli.commands.server
 
Abort() - Constructor for class org.infinispan.cli.commands.server.Abort
 
abortingJoin(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
abortingJoin(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
abortingJoin(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
abortingJoin(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
abortingJoin(Exception) - Method in interface org.infinispan.util.logging.Log
 
abortingJoin(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
abortingJoin$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
abortingJoin$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
abortingJoin$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
abortingJoin$str() - Method in class org.infinispan.query.logging.Log_$logger
 
abortingJoin$str() - Method in class org.infinispan.util.logging.Log_$logger
 
AbstractCacheTransaction - Class in org.infinispan.transaction
Base class for local and remote transaction.
AbstractCacheTransaction(GlobalTransaction, int, Equivalence<Object>) - Constructor for class org.infinispan.transaction.AbstractCacheTransaction
 
AbstractClusteringDependentLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
AbstractCommand - Class in org.infinispan.cli.commands
 
AbstractCommand() - Constructor for class org.infinispan.cli.commands.AbstractCommand
 
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
AbstractConfigurationChildBuilder - Class in org.infinispan.client.hotrod.configuration
AbstractConfigurationChildBuilder.
AbstractConfigurationChildBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
AbstractControlledLocalTopologyManager - Class in org.infinispan.util
Class to be extended to allow some control over the local topology manager when testing Infinispan.
AbstractControlledLocalTopologyManager(LocalTopologyManager) - Constructor for class org.infinispan.util.AbstractControlledLocalTopologyManager
 
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
 
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.commons.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.commons.marshall.AbstractDelegatingMarshaller
 
AbstractDelegatingTransport - Class in org.infinispan.remoting.transport
Designed to be overwrite.
AbstractDelegatingTransport(Transport) - Constructor for class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
AbstractEnlistmentAdapter - Class in org.infinispan.transaction
Base class for both Sync and XAResource enlistment adapters.
AbstractEnlistmentAdapter(CacheTransaction, CommandsFactory, RpcManager, TransactionTable, ClusteringDependentLogic, Configuration, TransactionCoordinator) - Constructor for class org.infinispan.transaction.AbstractEnlistmentAdapter
 
AbstractEnlistmentAdapter(CommandsFactory, RpcManager, TransactionTable, ClusteringDependentLogic, Configuration, TransactionCoordinator) - Constructor for class org.infinispan.transaction.AbstractEnlistmentAdapter
 
AbstractExternalizer<T> - Class in org.infinispan.commons.marshall
Base class for AdvancedExternalizer implementations that offers default implementations for some of its methods.
AbstractExternalizer() - Constructor for class org.infinispan.commons.marshall.AbstractExternalizer
 
AbstractFileLookup - Class in org.infinispan.commons.util
 
AbstractFileLookup() - Constructor for class org.infinispan.commons.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
 
AbstractGlobalTxExternalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
 
AbstractInProcessFuture<V> - Class in org.infinispan.commons.util.concurrent
An abstract Future that has "completed"
AbstractInProcessFuture() - Constructor for class org.infinispan.commons.util.concurrent.AbstractInProcessFuture
 
AbstractInProcessNotifyingFuture<V> - Class in org.infinispan.commons.util.concurrent
An abstract NotifyingFuture that has "completed"
AbstractInProcessNotifyingFuture() - Constructor for class org.infinispan.commons.util.concurrent.AbstractInProcessNotifyingFuture
 
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
 
AbstractInvocationContextFactory - Class in org.infinispan.context
Base class for InvocationContextFactory implementations.
AbstractInvocationContextFactory() - Constructor for class org.infinispan.context.AbstractInvocationContextFactory
 
AbstractIterator - Class in org.infinispan.query.impl
This is the abstract superclass of the 2 iterators.
AbstractIterator(QueryResultLoader, int, int, int) - Constructor for class org.infinispan.query.impl.AbstractIterator
 
AbstractJBossMarshaller - Class in org.infinispan.commons.marshall.jboss
Common parent for both embedded and standalone JBoss Marshalling-based marshallers.
AbstractJBossMarshaller() - Constructor for class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
AbstractJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.commons.marshall.jboss
 
AbstractJdbcStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
AbstractJdbcStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, ConnectionFactoryConfiguration, boolean) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
 
AbstractJdbcStoreConfigurationBuilder<T extends AbstractJdbcStoreConfiguration,S extends AbstractJdbcStoreConfigurationBuilder<T,S>> - Class in org.infinispan.persistence.jdbc.configuration
 
AbstractJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
AbstractJdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
AbstractJdbcStoreConfigurationChildBuilder.
AbstractJdbcStoreConfigurationChildBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
AbstractJmxRegistration - Class in org.infinispan.jmx
Parent class for top level JMX component registration.
AbstractJmxRegistration() - Constructor for class org.infinispan.jmx.AbstractJmxRegistration
 
AbstractJMXUrl - Class in org.infinispan.cli.connection.jmx
 
AbstractJMXUrl() - Constructor for class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
AbstractKeyOperation<T> - Class in org.infinispan.client.hotrod.impl.operations
Basic class for all hot rod operations that manipulate a key.
AbstractKeyOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
AbstractKeyValueOperation<T> - Class in org.infinispan.client.hotrod.impl.operations
Base class for all operations that manipulate a key and a value.
AbstractKeyValueOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
AbstractListenerImpl - Class in org.infinispan.notifications
Functionality common to both CacheManagerNotifierImpl and CacheNotifierImpl
AbstractListenerImpl() - Constructor for class org.infinispan.notifications.AbstractListenerImpl
 
AbstractListenerImpl.ListenerInvocation - Class in org.infinispan.notifications
Class that encapsulates a valid invocation for a given registered listener - containing a reference to the method to be invoked as well as the target object.
AbstractLocalCommand - Class in org.infinispan.commands.read
Abstract class
AbstractLocalCommand() - Constructor for class org.infinispan.commands.read.AbstractLocalCommand
 
AbstractLocalFlagAffectedCommand - Class in org.infinispan.commands
Base class for those local commands that can carry flags.
AbstractLocalFlagAffectedCommand() - Constructor for class org.infinispan.commands.AbstractLocalFlagAffectedCommand
 
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
 
AbstractMap<K,V> - Class in org.infinispan.commons.util
Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
AbstractMap() - Constructor for class org.infinispan.commons.util.AbstractMap
 
AbstractMap.SimpleEntry<K,V> - Class in org.infinispan.commons.util
 
AbstractMarshaller - Class in org.infinispan.commons.marshall
Abstract Marshaller implementation containing shared implementations.
AbstractMarshaller() - Constructor for class org.infinispan.commons.marshall.AbstractMarshaller
 
AbstractMarshaller - Class in org.infinispan.marshall
Deprecated.
use AbstractMarshaller instead
AbstractMarshaller() - Constructor for class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
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
 
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
 
AbstractPersistenceConfigurationChildBuilder - Class in org.infinispan.configuration.cache
AbstractPersistenceConfigurationChildBuilder.
AbstractPersistenceConfigurationChildBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
AbstractRemoteStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.remote.configuration
AbstractRemoteStoreConfigurationChildBuilder.
AbstractRemoteStoreConfigurationChildBuilder(RemoteStoreConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
AbstractServerCommand - Class in org.infinispan.cli.commands.server
 
AbstractServerCommand() - Constructor for class org.infinispan.cli.commands.server.AbstractServerCommand
 
AbstractStoreConfiguration - Class in org.infinispan.configuration.cache
 
AbstractStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
AbstractStoreConfigurationBuilder<T extends StoreConfiguration,S extends AbstractStoreConfigurationBuilder<T,S>> - Class in org.infinispan.configuration.cache
 
AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
AbstractStoreConfigurationChildBuilder<S> - Class in org.infinispan.configuration.cache
 
AbstractStoreConfigurationChildBuilder(StoreConfigurationBuilder<? extends AbstractStoreConfiguration, ? extends StoreConfigurationBuilder<?, ?>>) - 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.client.hotrod.impl.transport
Support class for transport implementations.
AbstractTransport(TransportFactory) - Constructor for class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
AbstractTransport - Class in org.infinispan.remoting.transport
Common transport-related behaviour
AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
 
AbstractTransportConfigurationChildBuilder - 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.commons.configuration
 
AbstractTypedPropertiesConfiguration(TypedProperties) - Constructor for class org.infinispan.commons.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(AuditEvent) - Method in class org.infinispan.checkstyle.filters.ExcludeTestPackages
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.ChunkCacheKey
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.FileCacheKey
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.FileListCacheKey
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.FileReadLockKey
 
accept(KeyVisitor<T>) - Method in interface org.infinispan.lucene.IndexScopedKey
 
accept(Object) - Method in interface org.infinispan.notifications.KeyFilter
 
accept(Visitor<ReturnType>) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
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, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Acquires RL on all locks aggregated 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
 
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
Acquires a readlock on all chunks for this file, to make sure chunks are not deleted while iterating on the group.
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Acquires a readlock, in order to prevent other invocations to SegmentReadLocker.deleteOrReleaseReadLock(String) from deleting the file.
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
doesn't do anything and returns true
acquireReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
Acquires a readlock, in order to prevent other invocations to SegmentReadLocker.deleteOrReleaseReadLock(String) from deleting the file.
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
 
activate(Object) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
activate(Object) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
activateObject(SocketAddress, TcpTransport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
ActivationInterceptor - Class in org.infinispan.interceptors
 
ActivationInterceptor() - Constructor for class org.infinispan.interceptors.ActivationInterceptor
 
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
 
active - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
Whether the the current cache is the coordinator and therefore SingletonStore is active.
activeStatusChanged(boolean) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Method called when the cache either becomes the coordinator or stops being the coordinator.
actual() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
actual - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
 
actual - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
 
actual - Variable in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
adapt(Runnable) - Static method in class org.infinispan.commons.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.commons.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.commons.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.commons.marshall
The BufferSizePredictor that automatically increases and decreases the predicted buffer size on feed back.
AdaptiveBufferSizePredictor() - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the default parameters.
AdaptiveBufferSizePredictor(int, int, int) - Constructor for class org.infinispan.commons.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(E) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Adds the specified element to this set if it is not already present.
add(K) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.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.commons.util.concurrent.jdk8backported.LongAdder
Adds the given value.
add(int, E) - Method in class org.infinispan.commons.util.ForwardingList
 
add(E) - Method in class org.infinispan.commons.util.ForwardingList
 
add(E) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
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(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
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(int, AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Deprecated.
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
This method provides compatibility with legacy AdvancedExternalizer.
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of AdvancedExternalizer implementations.
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
This method provides compatibility with legacy AdvancedExternalizer.
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 K>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
Adds all of the elements in the specified collection to this set, as if by calling EquivalentConcurrentHashMapV8.KeySetView.add(K) on each one.
addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ForwardingList
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ForwardingList
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
addAll(Collection<? extends E>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
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
 
addAllSynchronizedBlocks(Collection<TotalOrderLatch>) - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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
 
addClusterLoader() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cluster cache loader
addCoinToss(DldGlobalTransaction) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
addCommand(ProcessedCommand, int) - Method in interface org.infinispan.cli.CommandBuffer
 
addCommand(ProcessedCommand, int) - Method in class org.infinispan.cli.impl.CommandBufferImpl
 
addEntry(Object, MarshalledEntry) - Method in class org.infinispan.persistence.support.Bucket
 
addErroneousAttribute(String) - Method in exception org.infinispan.commons.CacheConfigurationException
 
addExecutorProperty(String, String) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addExecutorProperty(String, String) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addFailure(String, Throwable) - Method in exception org.infinispan.xsite.BackupFailureException
 
addFlags(Flag...) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
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>, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
 
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.
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.
addKeysLockedForClear() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
addListener(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
addListener(Object, KeyFilter) - Method in class org.infinispan.AbstractDelegatingCache
 
addListener(Object) - Method in class org.infinispan.CacheImpl
 
addListener(Object, KeyFilter) - Method in class org.infinispan.CacheImpl
 
addListener(Object) - Method in class org.infinispan.DecoratedCache
 
addListener(Object, KeyFilter) - 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, KeyFilter, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(Object, KeyFilter) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(Object, KeyFilter, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
Adds a listener to the component.
addListener(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
Adds a listener along with a class loader to use for the invocation
addListener(Object, KeyFilter) - Method in interface org.infinispan.notifications.FilteringListenable
Adds a listener to the component.
addListener(Object) - Method in interface org.infinispan.notifications.Listenable
Adds a listener to the component.
addListener(S, Object) - Method in interface org.infinispan.registry.ClusterRegistry
Adds a listener that is notified of changes to keys in a given scope.
addListener(S, KeyFilter, Object) - Method in interface org.infinispan.registry.ClusterRegistry
Adds a listener that is notified of changes to keys in a given scope and which match a given KeyFilter.
addListener(S, Object) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
addListener(S, KeyFilter, Object) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
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
 
addLockedKey(Object) - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
addMember(Address, float) - 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
 
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
 
addPrefixMatches(Argument, Collection<String>, List<String>) - Static method in class org.infinispan.cli.shell.Completer
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
addPrimaryOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
addProperty(String, String) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Defines a single property.
addProperty(String, String) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
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.InterceptorConfigurationBuilder
 
addProperty(String, String) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
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 - 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
 
addServer() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addServer() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a new remote server
addServer() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
addServer() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Adds a new remote server
addServers(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addServers(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addServers(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a list of remote servers in the form: host1[:port][;host2[:port]]...
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
addSingleFileStore() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a single file cache store
addSourceMigrator(SourceMigrator) - Method in class org.infinispan.upgrade.RollingUpgradeManager
Registers a migrator for a specific data format or endpoint.
addStats(String, String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
addStatus(Set<Integer>) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addStore(Class<T>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader which uses the specified builder class to build its configuration
addStore(StoreConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader which uses the specified builder instance to build its configuration
addSynchronizedBlock(TotalOrderLatch) - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
addToPendingCount(int) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Adds (atomically) the given value to the pending count.
addToTotalCount(long) - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
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.
addVersionRead(Object, EntryVersion) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
addVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Sets the version read for this key.
AdvancedAsyncCacheLoader - Class in org.infinispan.persistence.async
 
AdvancedAsyncCacheLoader(CacheLoader, AtomicReference<State>) - Constructor for class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
 
AdvancedAsyncCacheWriter - Class in org.infinispan.persistence.async
 
AdvancedAsyncCacheWriter(CacheWriter) - Constructor for class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
 
AdvancedCache<K,V> - Interface in org.infinispan
An advanced interface that exposes additional methods not available on Cache.
AdvancedCacheLoader<K,V> - Interface in org.infinispan.persistence.spi
A specialised extension of the CacheLoader interface that allows processing parallel iteration over the existing entries.
AdvancedCacheLoader.CacheLoaderTask<K,V> - Interface in org.infinispan.persistence.spi
Offers a callback to be invoked for parallel iteration over the entries in an external store.
AdvancedCacheLoader.KeyFilter<K> - Interface in org.infinispan.persistence.spi
Used during the parallel iteration to filter-out the keys that the caller is not interested in.
AdvancedCacheLoader.TaskContext - Interface in org.infinispan.persistence.spi
Used during the parallel iteration in order to offer the AdvancedCacheLoader.CacheLoaderTask a way of canceling the entry iteration.
AdvancedCacheWriter<K,V> - Interface in org.infinispan.persistence.spi
Defines advanced functionality for persisting data to an external storage.
AdvancedCacheWriter.PurgeListener<K> - Interface in org.infinispan.persistence.spi
AdvancedExternalizer<T> - Interface in org.infinispan.commons.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.
AdvancedExternalizer<T> - Interface in org.infinispan.marshall
Deprecated.
advancedExternalizers() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
AdvancedLoadWriteStore<K,V> - Interface in org.infinispan.persistence.spi
Advanced interface for interacting with an external store in a read-write mode.
AdvancedSingletonCacheWriter - Class in org.infinispan.persistence.support
 
AdvancedSingletonCacheWriter(CacheWriter, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
 
advanceExternalizerTypeClassesUndefined(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined(String) - Method in class org.infinispan.query.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined(String) - Method in interface org.infinispan.util.logging.Log
 
advanceExternalizerTypeClassesUndefined(String) - Method in class org.infinispan.util.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined$str() - Method in class org.infinispan.query.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined$str() - Method in class org.infinispan.util.logging.Log_$logger
 
affectedKeys - Variable in class org.infinispan.transaction.AbstractCacheTransaction
Holds all the locked keys that were acquired by the transaction allover the cluster.
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 class org.infinispan.lucene.logging.Log_$logger
 
afterCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
afterCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
afterCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
afterCompletionFailed(Synchronization, Throwable) - Method in interface org.infinispan.util.logging.Log
 
afterCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
afterCompletionFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
afterCompletionFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
afterCompletionFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
afterCompletionFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
afterCompletionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.commons.util.concurrent
For use with > 1 underlying network future
AggregatingNotifyingFutureImpl(T, int) - Constructor for class org.infinispan.commons.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() - 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
 
alwaysProvideInMemoryStateDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated() - Method in interface org.infinispan.util.logging.Log
 
alwaysProvideInMemoryStateDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
alwaysProvideInMemoryStateDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
and() - Method in interface org.infinispan.query.dsl.FilterConditionContext
Creates a new context and connects it with the current one using boolean AND.
and(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
Connects a given context with the current one using boolean AND.
AnyEquivalence<T> - Class in org.infinispan.commons.equivalence
A compare function for objects.
ApacheAvroMarshaller - Class in org.infinispan.client.hotrod.marshall
This is a portable serialization marshaller based on Apache Avro.
ApacheAvroMarshaller() - Constructor for class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
appendDelta(Delta) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
appendInterceptor(CommandInterceptor, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
Appends at the end.
apply(A) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.Action
 
apply(A, B) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.BiAction
 
apply(A, B) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.BiFun
 
apply(double, double) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.DoubleByDoubleToDouble
 
apply(A) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.Fun
 
apply(int, int) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.IntByIntToInt
 
apply(long, long) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.LongByLongToLong
 
apply(A, B) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ObjectByObjectToDouble
 
apply(A, B) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ObjectByObjectToInt
 
apply(A, B) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ObjectByObjectToLong
 
apply(A) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ObjectToDouble
 
apply(A) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ObjectToInt
 
apply(A) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.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
 
applyingChangeListLocally(List<LuceneWork>) - Method in interface org.infinispan.query.logging.Log
 
applyingChangeListLocally(List) - Method in class org.infinispan.query.logging.Log_$logger
 
applyingChangeListLocally$str() - Method in class org.infinispan.query.logging.Log_$logger
 
applyingChangeListRemotely(List<LuceneWork>) - Method in interface org.infinispan.query.logging.Log
 
applyingChangeListRemotely(List) - Method in class org.infinispan.query.logging.Log_$logger
 
applyingChangeListRemotely$str() - Method in class org.infinispan.query.logging.Log_$logger
 
applyModificationsSync(List<Modification>) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
applyProperties(Object, Properties) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
applyState(Address, int, Collection<StateChunk>) - Method in interface org.infinispan.statetransfer.StateConsumer
 
applyState(Address, int, Collection<StateChunk>) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
applyStreamWork(LuceneWork, IndexingMonitor) - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
applyStreamWork(LuceneWork, IndexingMonitor) - Method in class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
applyVersion(Metadata, Metadata) - Static method in class org.infinispan.metadata.Metadatas
Applies version in source metadata to target metadata, if no version in target metadata.
applyWork(List<LuceneWork>, IndexingMonitor) - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
applyWork(List<LuceneWork>, IndexingMonitor) - Method in class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
Argument - Interface in org.infinispan.cli.commands
 
ARRAY_LIST - Static variable in interface org.infinispan.marshall.core.Ids
 
ArrayExternalizers - Class in org.infinispan.marshall.exts
Externalizers for diverse array types.
ArrayExternalizers() - Constructor for class org.infinispan.marshall.exts.ArrayExternalizers
 
ArrayExternalizers.ListArray - Class in org.infinispan.marshall.exts
 
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.commons.util.AbstractMap
 
assertTypeConstructable(Class<?>, Class<?>...) - Method in class org.infinispan.factories.AbstractComponentFactory
 
assertValid(AtomicHashMap<?, ?>) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
asSet(T...) - Static method in class org.infinispan.commons.util.Util
 
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 store.
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
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.StoreConfiguration
Configuration for the async cache loader.
async() - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
Configuration for the async cache store.
ASYNC_EXECUTOR_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_REPLICATION_QUEUE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_TRANSPORT_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
AsyncCache<K,V> - Interface in org.infinispan.commons.api
AsyncCache.
AsyncCacheLoader - Class in org.infinispan.persistence.async
 
AsyncCacheLoader(CacheLoader, AtomicReference<State>) - Constructor for class org.infinispan.persistence.async.AsyncCacheLoader
 
AsyncCacheWriter - Class in org.infinispan.persistence.async
The AsyncCacheWriter is a delegating CacheStore that buffers changes and writes them asynchronously to the underlying CacheStore.
AsyncCacheWriter(CacheWriter) - Constructor for class org.infinispan.persistence.async.AsyncCacheWriter
 
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.
asyncConfiguration - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
 
AsyncConfigurationBuilder - Class in org.infinispan.configuration.cache
If configured all communications are asynchronous, in that whenever a thread sends a message sent over the wire, it does not wait for an acknowledgment before returning.
AsyncConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AsyncConfigurationBuilder
 
asyncExecutor - Variable in class org.infinispan.query.backend.QueryInterceptor
 
asyncExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
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() - 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
 
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 class org.infinispan.lucene.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted(InterruptedException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted(InterruptedException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted(InterruptedException) - Method in class org.infinispan.query.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
asyncStoreCoordinatorInterrupted(InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted$str() - Method in class org.infinispan.query.logging.Log_$logger
 
asyncStoreCoordinatorInterrupted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in class org.infinispan.lucene.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in class org.infinispan.query.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in interface org.infinispan.util.logging.Log
 
asyncStoreShutdownTimeoutTooHigh(long, long, long) - Method in class org.infinispan.util.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh$str() - Method in class org.infinispan.query.logging.Log_$logger
 
asyncStoreShutdownTimeoutTooHigh$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
ATOMIC_CLEAR_OPERATION - Static variable in interface org.infinispan.marshall.core.Ids
 
ATOMIC_HASH_MAP - Static variable in interface org.infinispan.marshall.core.Ids
 
ATOMIC_HASH_MAP_DELTA - Static variable in interface org.infinispan.marshall.core.Ids
 
ATOMIC_PUT_OPERATION - Static variable in interface org.infinispan.marshall.core.Ids
 
ATOMIC_REMOVE_OPERATION - Static variable in interface org.infinispan.marshall.core.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
 
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
 
AtomicHashMapProxy<K,V> - Class in org.infinispan.atomic
A layer of indirection around an AtomicHashMap to provide consistency and isolation for concurrent readers while writes may also be going on.
AtomicMap<K,V> - Interface in org.infinispan.atomic
This is a special type of Map geared for use in Infinispan.
AtomicMapLookup - Class in org.infinispan.atomic
A helper that locates or safely constructs and registers atomic maps with a given cache.
AtomicMapLookup() - Constructor for class org.infinispan.atomic.AtomicMapLookup
 
attachListener(FutureListener<T>) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
attachListener(FutureListener<V>) - Method in class org.infinispan.commons.util.concurrent.AbstractInProcessNotifyingFuture
 
attachListener(FutureListener<T>) - Method in class org.infinispan.commons.util.concurrent.BaseNotifyingFuture
 
attachListener(FutureListener<V>) - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
attachListener(FutureListener<E>) - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
attachListener(FutureListener<T>) - Method in interface org.infinispan.commons.util.concurrent.NotifyingFuture
Attaches a listener and returns the same future instance, to allow for 'building'.
attachListener(FutureListener<V>) - Method in class org.infinispan.util.concurrent.AbstractInProcessNotifyingFuture
 
attachListener(FutureListener<V>) - Method in class org.infinispan.util.concurrent.AbstractInProcessNotifyingFuture
 
attachListener(FutureListener<T>) - Method in class org.infinispan.util.concurrent.LegacyNotifyingFutureAdaptor
Deprecated.
 
attachListener(FutureListener<T>) - Method in interface org.infinispan.util.concurrent.NotifyingFuture
Deprecated.
Attaches a listener and returns the same future instance, to allow for 'building'.
Attribute - Enum in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
Attribute - Enum in org.infinispan.persistence.cli.configuration
Enumerates the attributes used by the CLI cache loader configuration
Attribute - Enum in org.infinispan.persistence.jdbc.configuration
Enumerates the attributes used by the JDBC cache stores configuration
Attribute - Enum in org.infinispan.persistence.remote.configuration
Enumerates the attributes used by the Remote cache store configuration
AutoBatchSupport - Class in org.infinispan.batch
Enables for automatic batching.
AutoBatchSupport() - Constructor for class org.infinispan.batch.AutoBatchSupport
 
autoChunkSize() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
When the segment size is larger than this number of bytes, separate segments will be created of this particular size.
autoChunkSize(int) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
When segment files are larger than this amount of bytes, the segment will be split into multiple chunks of this size.
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.factories.TestDelayFactory.Control
 
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.persistence.support.SingletonCacheWriter
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.commons.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.commons.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.distexec.DefaultExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
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.BlockingTaskAwareExecutorServiceImpl
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
awaitUntilReset() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
awaitUntilUnBlock() - Method in interface org.infinispan.transaction.totalorder.TotalOrderLatch
It waits for this synchronization block to be unblocked.
awaitUntilUnBlock() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 

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.AbstractDelegatingTransport
 
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
 
backupWrite(WriteCommand) - Method in interface org.infinispan.xsite.BackupSender
 
backupWrite(WriteCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
balancingStrategy(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(Class<? extends RequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
balancingStrategy(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(Class<? extends RequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(Class<? extends RequestBalancingStrategy>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
balancingStrategy() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
balancingStrategy(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
Base64 - Class in org.infinispan.commons.util
Encodes and decodes to and from Base64 notation.
Base64.InputStream - Class in org.infinispan.commons.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.OutputStream - Class in org.infinispan.commons.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.
BaseBackupInterceptor - Class in org.infinispan.interceptors.xsite
 
BaseBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
baseCfg - Variable in class org.infinispan.commons.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
 
BaseLockFactory - Class in org.infinispan.lucene.locking
Default factory for locks obtained in InfinispanDirectory, this factory produces instances of BaseLuceneLock.
BaseLockFactory(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.locking.BaseLockFactory
 
BaseNotifyingFuture<T> - Class in org.infinispan.commons.util.concurrent
 
BaseNotifyingFuture() - Constructor for class org.infinispan.commons.util.concurrent.BaseNotifyingFuture
 
BaseProtoStreamMarshaller - Class in org.infinispan.query.remote.client
 
BaseProtoStreamMarshaller() - Constructor for class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
 
BaseQueryBuilder<T extends Query> - Class in org.infinispan.query.dsl.impl
 
BaseQueryBuilder(Class) - Constructor for class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
BaseQueryFactory<T extends Query> - Class in org.infinispan.query.dsl.impl
 
BaseQueryFactory() - Constructor for class org.infinispan.query.dsl.impl.BaseQueryFactory
 
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
 
BaseTypeConverterInterceptor - Class in org.infinispan.interceptors.compat
Base implementation for an interceptor that applies type conversion to the data stored in the cache.
BaseTypeConverterInterceptor() - Constructor for class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
BasicCache<K,V> - Interface in org.infinispan.api
Deprecated.
use BasicCache instead
BasicCache<K,V> - Interface in org.infinispan.commons.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
Deprecated.
BasicCacheContainer - Interface in org.infinispan.commons.api
BasicCacheContainer defines the methods used to obtain a BasicCache.
BasicLogFactory - Class in org.infinispan.commons.logging
Factory that creates Log instances.
BasicLogFactory() - Constructor for class org.infinispan.commons.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 BatchingCache.startBatch() and BatchingCache.endBatch(boolean) calls.
BatchContainer() - Constructor for class org.infinispan.batch.BatchContainer
 
batchContainer - Variable in class org.infinispan.CacheImpl
 
BatchingCache - Interface in org.infinispan.commons.api
The BatchingCache is implemented by all caches which support batching
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
 
batchSize() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
batchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
When doing repetitive DB inserts this will be batched according to this parameter.
batchSize() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
batchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Repetitive DB operations this are batched according to this parameter.
BeanUtils - Class in org.infinispan.commons.util
Simple JavaBean manipulation helper methods
BeanUtils() - Constructor for class org.infinispan.commons.util.BeanUtils
 
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 class org.infinispan.lucene.logging.Log_$logger
 
beforeCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
beforeCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
beforeCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
beforeCompletionFailed(Synchronization, Throwable) - Method in interface org.infinispan.util.logging.Log
 
beforeCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
beforeCompletionFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
beforeCompletionFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
beforeCompletionFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
beforeCompletionFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
beforeCompletionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
beforeConfirmRebalance(String, int, Throwable) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
beforeHandleConsistentHashUpdate(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
beforeHandleRebalance(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
beforeInvalidation(Set<Integer>, Set<Integer>) - Method in interface org.infinispan.statetransfer.StateConsumerImpl.KeyInvalidationListener
 
Begin - Class in org.infinispan.cli.commands.server
 
Begin() - Constructor for class org.infinispan.cli.commands.server.Begin
 
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.
between(Object, Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is between the given range limits.
binaryTable() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
binaryTable() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
Allows configuration of table-specific parameters such as column names and types for the table used to store entries with binary keys
binaryTable() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
binaryTable() - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationChildBuilder
Allows configuration of table-specific parameters such as column names and types for the table used to store entries with binary keys
block() - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
block() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
BlockingRunnable - Interface in org.infinispan.util.concurrent
A special Runnable (for the particular case of Total Order) that is only sent to a thread when it is ready to be executed without blocking the thread

Use case: - in Total Order, when the prepare is delivered, the runnable blocks waiting for the previous conflicting transactions to be finished.

BlockingTaskAwareExecutorService - Interface in org.infinispan.util.concurrent
Executor service that is aware of BlockingRunnable and only dispatch the runnable to a thread when it has low (or no) probability of blocking the thread.
BlockingTaskAwareExecutorServiceImpl - Class in org.infinispan.util.concurrent
A special executor service that accepts a BlockingRunnable.
BlockingTaskAwareExecutorServiceImpl(ExecutorService, TimeService) - Constructor for class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
BOOLEAN - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
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>, Equivalence<K>, Equivalence<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, Equivalence<K>, Equivalence<V>) - 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, Equivalence<K>, Equivalence<V>) - 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, Equivalence<K>, Equivalence<V>) - 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(Equivalence<K>, Equivalence<V>) - 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, Equivalence, Equivalence) - 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
 
boxKey(K) - Method in interface org.infinispan.compat.TypeConverter
Covert a instance of cached key type into an instance of target key type.
boxValue(V) - Method in interface org.infinispan.compat.TypeConverter
Covert a instance of cached key type into an instance of target key type.
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
 
broadcast(ClusteredQueryCommand) - Method in class org.infinispan.query.clustered.ClusteredQueryInvoker
Broadcast this ClusteredQueryCommand to all cluster nodes.
broadcastRemoteCommands(ReplicableCommand, ResponseMode, long, boolean, RspFilter, boolean, boolean, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
broadcastRpcCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
broadcastRpcCommand(ReplicableCommand, boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
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
Deprecated.
this method may be removed in the future. Use #invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
broadcastRpcCommandInFuture(ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
this method may be removed in the future. Use #invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
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.persistence.support
A bucket is where entries are stored.
Bucket(Equivalence<Object>) - Constructor for class org.infinispan.persistence.support.Bucket
 
Bucket(Map<Object, MarshalledEntry>, Equivalence<Object>) - Constructor for class org.infinispan.persistence.support.Bucket
 
BufferSizePredictor - Interface in org.infinispan.commons.marshall
Buffer size predictor
BufferSizePredictor - Interface in org.infinispan.marshall
Deprecated.
BufferSizePredictorAdapter - Class in org.infinispan.marshall
Deprecated.
BufferSizePredictorAdapter(BufferSizePredictor) - Constructor for class org.infinispan.marshall.BufferSizePredictorAdapter
Deprecated.
 
build() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
build() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
build() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Builds a configuration object
build() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQueryBuilder
 
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() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
build() - Method in interface org.infinispan.metadata.Metadata.Builder
Build a metadata instance.
build() - Method in interface org.infinispan.query.dsl.QueryBuilder
Builds the query object.
build() - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
 
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
 
BuildContext - Interface in org.infinispan.lucene.directory
Building context to set construction parameters of Infinispan Directory instances
buildCreateCacheCommand(String, String) - Method in interface org.infinispan.commands.CommandsFactory
Same as #buildCreateCacheCommand(String, String, false, 0).
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(Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a EntrySetCommand
buildEntrySetCommand(Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
Builder<T> - Interface in org.infinispan.commons.configuration
Builder.
Builder(Hash, int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHash) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
Builder() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Builder
 
builder() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
builder() - Method in interface org.infinispan.metadata.Metadata
Returns an instance of Metadata.Builder which can be used to build new instances of Metadata instance which are full copies of this Metadata.
builderFor(B) - Static method in class org.infinispan.commons.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
 
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>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
buildGetKeyValueCommand(Object, Set<Flag>, boolean) - 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(Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a KeySetCommand
buildKeySetCommand(Set<Flag>) - 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, 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, 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, Metadata, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutKeyValueCommand
buildPutKeyValueCommand(Object, Object, Metadata, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map<?, ?>, Metadata, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutMapCommand
buildPutMapCommand(Map<?, ?>, Metadata, Set<Flag>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildQueryBuilderForClass(Class<?>) - Method in class org.infinispan.query.impl.SearchManagerImpl
 
buildQueryBuilderForClass(Class<?>) - Method in interface org.infinispan.query.SearchManager
Experimental.
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, Metadata, Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, Metadata, 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(Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SizeCommand
buildSizeCommand(Set<Flag>) - 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(Set<Flag>) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ValuesCommand
buildValuesCommand(Set<Flag>) - 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
 
BuiltBy - Annotation Type in org.infinispan.commons.configuration
BuiltBy.
BULK_GET_KEYS_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
BULK_GET_KEYS_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
BULK_GET_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
BULK_GET_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
BulkGetKeysOperation - Class in org.infinispan.client.hotrod.impl.operations
Reads all keys.
BulkGetKeysOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[], int) - Constructor for class org.infinispan.client.hotrod.impl.operations.BulkGetKeysOperation
 
BulkGetOperation - Class in org.infinispan.client.hotrod.impl.operations
Reads more keys at a time.
BulkGetOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[], int) - Constructor for class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
ByRef<T> - Class in org.infinispan.commons.util
This class can be used to pass an argument by reference.
ByRef(T) - Constructor for class org.infinispan.commons.util.ByRef
 
BYTE - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
BYTE_ARRAY_KEY - Static variable in interface org.infinispan.marshall.core.Ids
 
BYTE_BUFFER - Static variable in interface org.infinispan.commons.marshall.Ids
 
ByteArrayEquivalence - Class in org.infinispan.commons.equivalence
A compare function for unsigned byte arrays.
ByteArrayEquivalence() - Constructor for class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
ByteBuffer - Interface in org.infinispan.commons.io
A byte buffer that exposes the internal byte array with minimal copying.
ByteBufferFactory - Interface in org.infinispan.commons.io
Used for building instances of ByteBuffer.
ByteBufferFactoryImpl - Class in org.infinispan.commons.io
 
ByteBufferFactoryImpl() - Constructor for class org.infinispan.commons.io.ByteBufferFactoryImpl
 
ByteBufferImpl - Class in org.infinispan.commons.io
A byte buffer that exposes the internal byte array with minimal copying
ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.commons.io.ByteBufferImpl
 
ByteBufferImpl - Class in org.infinispan.io
Deprecated.
ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.io.ByteBufferImpl
Deprecated.
 
ByteBufferImpl.Externalizer - Class in org.infinispan.commons.io
 

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 - Class in org.infinispan.cli.commands.server
 
Cache() - Constructor for class org.infinispan.cli.commands.server.Cache
 
cache - Variable in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
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.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
cache - Variable in class org.infinispan.query.clustered.DistributedIterator
 
cache - Variable in class org.infinispan.query.impl.CacheQueryImpl
 
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.core.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.core.Ids
 
CACHE_RPC_COMMAND - Static variable in interface org.infinispan.marshall.core.Ids
 
CACHE_STOPPED_TOPOLOGY_ID - Static variable in class org.infinispan.transaction.TransactionTable
 
CACHE_TOPOLOGY - Static variable in interface org.infinispan.marshall.core.Ids
 
cacheBackupsDataToSameSite(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheBackupsDataToSameSite(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheBackupsDataToSameSite(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheBackupsDataToSameSite(String) - Method in class org.infinispan.query.logging.Log_$logger
 
cacheBackupsDataToSameSite(String) - Method in interface org.infinispan.util.logging.Log
 
cacheBackupsDataToSameSite(String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheBackupsDataToSameSite$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheBackupsDataToSameSite$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheBackupsDataToSameSite$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheBackupsDataToSameSite$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheBackupsDataToSameSite$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.commons
An exception that represents an error in the configuration.
CacheConfigurationException(Exception) - Constructor for exception org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String, String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String, Throwable) - Constructor for exception org.infinispan.commons.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.commons
Thrown when operations on Cache fail unexpectedly.
CacheException() - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(Throwable) - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(String) - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(String, Throwable) - Constructor for exception org.infinispan.commons.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, boolean, boolean, float) - Constructor for class org.infinispan.topology.CacheJoinInfo
 
CacheJoinInfo.Externalizer - Class in org.infinispan.topology
 
CacheListenerException - Exception in org.infinispan.commons
Wraps exceptions produced by listener implementations.
CacheListenerException() - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheListenerException(Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheListenerException(String) - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheListenerException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheLoader<K,V> - Interface in org.infinispan.persistence.spi
Defines the logic for loading data from an external storage.
cacheLoaderConfigurationCannotBeNull() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull() - Method in interface org.infinispan.util.logging.Log
 
cacheLoaderConfigurationCannotBeNull() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheLoaderConfigurationCannotBeNull$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheLoaderIgnoringKey(Object) - Method in interface org.infinispan.lucene.logging.Log
 
cacheLoaderIgnoringKey(Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheLoaderIgnoringKey$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in class org.infinispan.query.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in interface org.infinispan.util.logging.Log
 
cacheLoaderIgnoringUnexpectedFile(Object, String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheLoaderIgnoringUnexpectedFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CacheLoaderInterceptor - Class in org.infinispan.interceptors
 
CacheLoaderInterceptor() - Constructor for class org.infinispan.interceptors.CacheLoaderInterceptor
 
CacheManager - Interface in org.infinispan.manager
Deprecated.
cacheManager - Variable in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
cacheManagerAlreadyRegistered(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheManagerAlreadyRegistered(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheManagerAlreadyRegistered(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheManagerAlreadyRegistered(String) - Method in class org.infinispan.query.logging.Log_$logger
 
cacheManagerAlreadyRegistered(String) - Method in interface org.infinispan.util.logging.Log
 
cacheManagerAlreadyRegistered(String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheManagerAlreadyRegistered$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheManagerAlreadyRegistered$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheManagerAlreadyRegistered$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheManagerAlreadyRegistered$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheManagerAlreadyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
If JMX statistics are enabled, this property represents the name of this cache manager.
CacheManagerNotifier - Interface in org.infinispan.notifications.cachemanagerlistener
Notifications for the cache manager
CacheManagerNotifierImpl - Class in org.infinispan.notifications.cachemanagerlistener
Global, shared notifications on the cache manager.
CacheManagerNotifierImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStarted(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lucene.LifecycleCallbacks
 
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.core
A cache-scoped marshaller.
CacheMarshaller(VersionAwareMarshaller) - Constructor for class org.infinispan.marshall.core.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.client.hotrod.impl.operations.HotRodOperation
 
cacheName(byte[]) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
cacheName - Variable in class org.infinispan.commands.remote.BaseRpcCommand
 
cacheName - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
cacheName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
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
 
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 class org.infinispan.lucene.logging.Log_$logger
 
cacheNotStarted() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheNotStarted() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheNotStarted() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheNotStarted() - Method in interface org.infinispan.util.logging.Log
 
cacheNotStarted() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheNotStarted$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheNotStarted$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheNotStarted$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheNotStarted$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheNotStarted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CacheQuery - Interface in org.infinispan.query
A cache-query is what will be returned when the getQuery() method is run on SearchManagerImpl.
CacheQueryImpl - Class in org.infinispan.query.impl
Implementation class of the CacheQuery interface.
CacheQueryImpl(Query, SearchFactoryIntegrator, AdvancedCache<?, ?>, KeyTransformationHandler, Class<?>...) - Constructor for class org.infinispan.query.impl.CacheQueryImpl
 
CacheQueryImpl(Query, SearchFactoryIntegrator, AdvancedCache<?, ?>, KeyTransformationHandler, TimeoutExceptionFactory, Class<?>...) - Constructor for class org.infinispan.query.impl.CacheQueryImpl
 
CacheRpcCommand - Interface in org.infinispan.commands.remote
The RpcManager only replicates commands wrapped in a CacheRpcCommand.
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 - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is started.
cacheStarted(Event) - Method in class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
Cache started, check whether the cache is the coordinator and set the singleton store's active status.
cacheStarted(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStarted.
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.query.impl.LifecycleManager
Registers the Search interceptor in the cache before it gets started
cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
 
cacheStopped(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
CacheStopped - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is stopped.
cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
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
 
cacheStopping(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
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.
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
 
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.
cacheViewRollbackIdMismatch(int, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheViewRollbackIdMismatch(int, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheViewRollbackIdMismatch(int, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheViewRollbackIdMismatch(int, int) - Method in class org.infinispan.query.logging.Log_$logger
 
cacheViewRollbackIdMismatch(int, int) - Method in interface org.infinispan.util.logging.Log
 
cacheViewRollbackIdMismatch(int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheViewRollbackIdMismatch$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cacheViewRollbackIdMismatch$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cacheViewRollbackIdMismatch$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cacheViewRollbackIdMismatch$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cacheViewRollbackIdMismatch$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CacheWriter<K,V> - Interface in org.infinispan.persistence.spi
Allows persisting data to an external storage, as opposed to the CacheLoader.
CacheWriterInterceptor - 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.
CacheWriterInterceptor() - Constructor for class org.infinispan.interceptors.CacheWriterInterceptor
 
CacheWriterInterceptor.Updater - Class in org.infinispan.interceptors
 
calculateRank(ViewChangedEvent) - Method in class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
 
call() - Method in class org.infinispan.tasks.GlobalKeySetTask
 
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
 
canBlock() - Method in class org.infinispan.commands.CreateCacheCommand
 
canBlock() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
canBlock() - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
canBlock() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
canBlock() - Method in class org.infinispan.commands.read.MapCombineCommand
 
canBlock() - Method in class org.infinispan.commands.read.ReduceCommand
 
canBlock() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
canBlock() - Method in class org.infinispan.commands.remote.MultipleRpcCommand
 
canBlock() - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
canBlock() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
canBlock() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
canBlock() - Method in class org.infinispan.commands.RemoveCacheCommand
 
canBlock() - Method in interface org.infinispan.commands.ReplicableCommand
If true, the command is processed asynchronously in a thread provided by an Infinispan thread pool.
canBlock() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
canBlock() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
canBlock() - Method in class org.infinispan.commands.write.ClearCommand
 
canBlock() - Method in class org.infinispan.commands.write.PutMapCommand
 
canBlock() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
canBlock() - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
canBlock() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
canBlock() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
canBlock() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
cancel(boolean) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
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(boolean) - Method in class org.infinispan.commons.util.concurrent.AbstractInProcessFuture
 
cancel(boolean) - Method in class org.infinispan.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
cancel(boolean) - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
cancel(boolean) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Attempts to cancel execution of this task.
cancel(boolean) - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
cancel(boolean) - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
cancel(boolean) - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
cancel() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
cancel() - Method in class org.infinispan.statetransfer.OutboundTransferTask
Cancel the whole task.
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.metadata.MetadataMortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
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
 
canLoad(Object) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
canLoad(Object) - Method in class org.infinispan.interceptors.ClusteredCacheLoaderInterceptor
 
CANNOT_ASSUME_DENOM_IS_POWER_OF_TWO - Static variable in class org.infinispan.io.ModularArithmetic
 
cannotEnableHotRodWrapping() - Method in interface org.infinispan.persistence.remote.logging.Log
 
cannotEnableHotRodWrapping() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotEnableHotRodWrapping$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotLoadHotRodEntryWrapper(Exception) - Method in interface org.infinispan.persistence.remote.logging.Log
 
cannotLoadHotRodEntryWrapper(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotLoadHotRodEntryWrapper$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotResolveExternalizerReader(ComponentStatus, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotResolveExternalizerReader(ComponentStatus, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotResolveExternalizerReader(ComponentStatus, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotResolveExternalizerReader(ComponentStatus, int) - Method in class org.infinispan.query.logging.Log_$logger
 
cannotResolveExternalizerReader(ComponentStatus, int) - Method in interface org.infinispan.util.logging.Log
 
cannotResolveExternalizerReader(ComponentStatus, int) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotResolveExternalizerReader$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotResolveExternalizerReader$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotResolveExternalizerReader$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotResolveExternalizerReader$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cannotResolveExternalizerReader$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in class org.infinispan.query.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in interface org.infinispan.util.logging.Log
 
cannotRespondToCommit(GlobalTransaction, String) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToCommit$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotRespondToCommit$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotRespondToCommit$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotRespondToCommit$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cannotRespondToCommit$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in class org.infinispan.query.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in interface org.infinispan.util.logging.Log
 
cannotRespondToRollback(GlobalTransaction, String) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToRollback$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotRespondToRollback$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotRespondToRollback$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotRespondToRollback$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cannotRespondToRollback$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotSelectRandomMembers(int, List) - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotSelectRandomMembers(int, List) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotSelectRandomMembers(int, List) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotSelectRandomMembers(int, List) - Method in class org.infinispan.query.logging.Log_$logger
 
cannotSelectRandomMembers(int, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
cannotSelectRandomMembers(int, List) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotSelectRandomMembers$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
cannotSelectRandomMembers$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
cannotSelectRandomMembers$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
cannotSelectRandomMembers$str() - Method in class org.infinispan.query.logging.Log_$logger
 
cannotSelectRandomMembers$str() - Method in class org.infinispan.util.logging.Log_$logger
 
canRead() - Method in class org.infinispan.io.GridFile
 
canWrite() - Method in class org.infinispan.io.GridFile
 
capacityFactor() - Method in class org.infinispan.configuration.cache.HashConfiguration
Controls the proportion of entries that will reside on the local node, compared to the other nodes in the cluster.
capacityFactor(float) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Controls the proportion of entries that will reside on the local node, compared to the other nodes in the cluster.
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.distribution.L1NonTxInterceptor
 
cdl - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
cdl - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
cf - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
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 class org.infinispan.lucene.logging.Log_$logger
 
channelNotSetUp() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
channelNotSetUp() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
channelNotSetUp() - Method in class org.infinispan.query.logging.Log_$logger
 
channelNotSetUp() - Method in interface org.infinispan.util.logging.Log
 
channelNotSetUp() - Method in class org.infinispan.util.logging.Log_$logger
 
channelNotSetUp$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
channelNotSetUp$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
channelNotSetUp$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
channelNotSetUp$str() - Method in class org.infinispan.query.logging.Log_$logger
 
channelNotSetUp$str() - Method in class org.infinispan.util.logging.Log_$logger
 
checkForErrorsInResponseStatus(Transport, HeaderParams, short) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
checkForReadyTasks() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
checkForReadyTasks() - Method in interface org.infinispan.util.concurrent.BlockingTaskAwareExecutorService
It checks for tasks ready to be processed in the thread.
checkForReadyTasks() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
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
 
checkTotalOrderSupported() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
checkTotalOrderSupported() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
checkTotalOrderSupported() - Method in interface org.infinispan.remoting.transport.Transport
check if the transport has configured with total order deliver properties (has the sequencer in JGroups protocol stack.
CHUNK_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
ChunkCacheKey - Class in org.infinispan.lucene
Used as a key to distinguish file chunk in cache.
ChunkCacheKey(String, String, int, int) - Constructor for class org.infinispan.lucene.ChunkCacheKey
 
ChunkCacheKey.Externalizer - Class in org.infinispan.lucene
 
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.
chunkSize(int) - Method in interface org.infinispan.lucene.directory.BuildContext
Sets the chunkSize option for the Directory being created.
chunkSize(int) - Method in class org.infinispan.lucene.impl.DirectoryBuilderImpl
 
CLASS_LOADER - Static variable in class org.infinispan.factories.KnownComponentNames
 
ClassFinder - Class in org.infinispan.commons.util
Find infinispan classes utility
ClassFinder() - Constructor for class org.infinispan.commons.util.ClassFinder
 
classLoader(ClassLoader) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
classLoader() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
classLoader(ClassLoader) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
classLoader(ClassLoader) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
 
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
 
ClassLoaderAwareFilteringListenable - Interface in org.infinispan.notifications
Interface that enhances FilteringListenable with the possibility of specifying the ClassLoader which should be set as the context class loader for the invoked listener method
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
classNotFoundIntegratingState(ClassNotFoundException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
classNotFoundIntegratingState(ClassNotFoundException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
classNotFoundIntegratingState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
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() - 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 - Class in org.infinispan.cli.commands.server
 
Clear() - Constructor for class org.infinispan.cli.commands.server.Clear
 
clear() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clear() - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
clear() - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Removes all of the elements from this set.
clear() - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
 
clear() - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
Clear the cached marshallable type hints.
clear() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
clear() - Method in class org.infinispan.commons.util.ForwardingList
 
clear() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
clear() - Method in interface org.infinispan.container.DataContainer
Removes all entries in the container
clear() - Method in class org.infinispan.container.DefaultDataContainer
 
clear() - Method in class org.infinispan.DecoratedCache
 
clear() - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
 
clear() - Method in class org.infinispan.persistence.file.SingleFileStore
 
clear() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
clear() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
clear() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
Clear - Class in org.infinispan.persistence.modifications
 
Clear() - Constructor for class org.infinispan.persistence.modifications.Clear
 
clear() - Method in class org.infinispan.persistence.remote.RemoteStore
 
clear() - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter
Removes all the data from the storage.
clear() - Method in class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
 
clear() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
clear(S) - Method in interface org.infinispan.registry.ClusterRegistry
 
clear(S) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
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.ReadOnlyDataContainerBackedKeySet
 
CLEAR_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CLEAR_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
clearAll() - Method in interface org.infinispan.registry.ClusterRegistry
 
clearAll() - Method in class org.infinispan.registry.ClusterRegistryImpl
 
clearAllStores(boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Invokes AdvancedCacheWriter.clear() on all the stores that aloes it.
clearAllStores(boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
clearAsync() - Method in class org.infinispan.AbstractDelegatingCache
 
clearAsync() - Method in interface org.infinispan.api.BasicCache
Deprecated.
Asynchronous version of Map.clear().
clearAsync() - Method in class org.infinispan.CacheImpl
 
clearAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clearAsync() - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #clear().
clearAsync() - Method in class org.infinispan.DecoratedCache
 
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
 
clearGroupers() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Clear the groupers
clearLock(String) - Method in class org.infinispan.lucene.locking.BaseLockFactory
clearLock(String) - Method in class org.infinispan.lucene.locking.TransactionalLockFactory
clearLockedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.ImmutableContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clearLockedKeys() - Method in interface org.infinispan.context.InvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
clearLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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 - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to clear operation as defined by Hot Rod protocol specification.
ClearOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
ClearOperation.Externalizer - Class in org.infinispan.atomic
 
clearProperties() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Clears the interceptor properties
clearProperties() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Clears the transport properties
clearRemoteLocksAcquired() - Method in class org.infinispan.transaction.LocalTransaction
 
clearStores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Removes any configured stores from this builder.
clearThreadLocal() - Method in interface org.infinispan.context.InvocationContextContainer
Remove the stored InvocationContext from the calling thread.
clearThreadLocal() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
CLIENT_INTELLIGENCE_BASIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CLIENT_INTELLIGENCE_HASH_DISTRIBUTION_AWARE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CLIENT_INTELLIGENCE_TOPOLOGY_AWARE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
clientIntel(byte) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
CLInterfaceLoader<K,V> - Class in org.infinispan.persistence.cli
A read-only cache loader retrieving data from another cache(s) using the Command Line Interface.
CLInterfaceLoader() - Constructor for class org.infinispan.persistence.cli.CLInterfaceLoader
 
CLInterfaceLoaderConfiguration - Class in org.infinispan.persistence.cli.configuration
// TODO: Document this
CLInterfaceLoaderConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, String) - Constructor for class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfiguration
 
CLInterfaceLoaderConfigurationBuilder - Class in org.infinispan.persistence.cli.configuration
// TODO: Document this
CLInterfaceLoaderConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationBuilder
 
CLInterfaceLoaderConfigurationParser60 - Class in org.infinispan.persistence.cli.configuration
XML parser for CLI cache loader configuration.
CLInterfaceLoaderConfigurationParser60() - Constructor for class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationParser60
 
CLInterfaceTargetMigrator - Class in org.infinispan.persistence.cli.upgrade
// TODO: Document this
CLInterfaceTargetMigrator() - Constructor for class org.infinispan.persistence.cli.upgrade.CLInterfaceTargetMigrator
 
clone() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
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.lucene.impl.InfinispanIndexInputV3
 
clone() - Method in class org.infinispan.lucene.impl.InfinispanIndexInputV4
 
clone() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
clone() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
clone() - Method in class org.infinispan.transaction.RemoteTransaction
 
clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
cloneWithMarshaller(Marshaller, T) - Static method in class org.infinispan.commons.util.Util
Clones parameter x of type T with a given Marshaller reference;
close() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
close() - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
close() - Method in interface org.infinispan.cli.io.IOAdapter
 
close() - Method in class org.infinispan.cli.io.StreamIOAdapter
 
close() - Method in class org.infinispan.commons.util.Base64.OutputStream
Flushes and closes (I think, in the superclass) the stream.
close(Closeable) - Static method in class org.infinispan.commons.util.Util
 
close(Socket) - Static method in class org.infinispan.commons.util.Util
 
close(Closeable...) - Static method in class org.infinispan.commons.util.Util
 
close(Context) - Static method in class org.infinispan.commons.util.Util
 
close() - Method in class org.infinispan.io.GridInputStream
 
close() - Method in class org.infinispan.io.GridOutputStream
 
close() - Method in class org.infinispan.io.ReadableGridFileChannel
 
close() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
close() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
close() - Method in class org.infinispan.io.WritableGridFileChannel
 
close() - Method in class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
close() - Method in class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
close() - Method in interface org.infinispan.lucene.cacheloader.InternalDirectoryContract
 
close() - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
close() - Method in class org.infinispan.lucene.impl.SingleChunkIndexInput
 
close() - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
close() - Method in class org.infinispan.query.clustered.DistributedIterator
 
close() - Method in class org.infinispan.query.clustered.DistributedLazyIterator
 
close() - Method in class org.infinispan.query.impl.EagerIterator
 
close() - Method in class org.infinispan.query.impl.LazyIterator
 
close() - Method in class org.infinispan.query.impl.NullFilteringResultIterator
 
close() - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
close() - Method in class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
close() - Method in interface org.infinispan.query.ResultIterator
This method must be called on your iterator once you have finished so that any local or remote resources can be freed up.
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(InputStream) - Static method in class org.infinispan.util.Util
Deprecated.
 
closeChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
closeMarshaller() - Method in interface org.infinispan.commons.marshall.jboss.RiverCloseListener
 
closeUnmarshaller() - Method in interface org.infinispan.commons.marshall.jboss.RiverCloseListener
 
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
 
clusterDependentLogic - Variable in class org.infinispan.distexec.DefaultExecutorService
 
clustered(boolean) - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
clustered - Variable in class org.infinispan.transaction.TransactionTable
 
CLUSTERED_QUERY - Static variable in interface org.infinispan.query.impl.ModuleCommandIds
 
ClusteredActivationInterceptor - Class in org.infinispan.interceptors
The same as a regular cache loader interceptor, except that it contains additional logic to force loading from the cache loader if needed on a remote node, in certain conditions.
ClusteredActivationInterceptor() - Constructor for class org.infinispan.interceptors.ClusteredActivationInterceptor
 
ClusteredCacheLoaderInterceptor - Class in org.infinispan.interceptors
The same as a regular cache loader interceptor, except that it contains additional logic to force loading from the cache loader if needed on a remote node, in certain conditions.
ClusteredCacheLoaderInterceptor() - Constructor for class org.infinispan.interceptors.ClusteredCacheLoaderInterceptor
 
ClusteredCacheQueryImpl - Class in org.infinispan.query.clustered
A extension of CacheQueryImpl used for distributed queries.
ClusteredCacheQueryImpl(Query, SearchFactoryIntegrator, ExecutorService, AdvancedCache<?, ?>, KeyTransformationHandler, Class<?>...) - Constructor for class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
clusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
ClusteredDoc - Interface in org.infinispan.query.clustered
ClusteredDoc.
ClusteredFieldDoc - Class in org.infinispan.query.clustered
ClusteredFIeldDoc.
ClusteredFieldDoc(FieldDoc, UUID, int) - Constructor for class org.infinispan.query.clustered.ClusteredFieldDoc
 
ClusteredGetCommand - Class in org.infinispan.commands.remote
Issues a remote get call.
ClusteredGetCommand(String) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetCommand(Object, String, Set<Flag>, boolean, GlobalTransaction, Equivalence) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetResponseValidityFilter - Class in org.infinispan.remoting.responses
A filter that tests the validity of ClusteredGetCommands.
ClusteredGetResponseValidityFilter(Collection<Address>, Address) - Constructor for class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
ClusteredQueryCommand - Class in org.infinispan.query.clustered
Encapsulates all rpc calls for distributed queries actions
ClusteredQueryCommand(String) - Constructor for class org.infinispan.query.clustered.ClusteredQueryCommand
For CommandFactory only.
ClusteredQueryCommandType - Enum in org.infinispan.query.clustered
Types of ClusteredQueryCommandWorker.
ClusteredQueryCommandWorker - Class in org.infinispan.query.clustered.commandworkers
ClusteredQueryCommandWorker.
ClusteredQueryCommandWorker() - Constructor for class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
ClusteredQueryInvoker - Class in org.infinispan.query.clustered
Invoke a CusteredQueryCommand on the cluster, including on own node.
ClusteredRepeatableReadEntry - Class in org.infinispan.container.entries
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
ClusteredRepeatableReadEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
ClusteredScoreDoc - Class in org.infinispan.query.clustered
ClusteredScoreDoc.
ClusteredScoreDoc(ScoreDoc, UUID, int) - Constructor for class org.infinispan.query.clustered.ClusteredScoreDoc
 
ClusteredTopDocs - Class in org.infinispan.query.clustered
ClusteredTopDocs.
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 - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
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.DistributionLogic - Class in org.infinispan.interceptors.locking
This logic is used in distributed mode caches.
ClusteringDependentLogic.InvalidationLogic - Class in org.infinispan.interceptors.locking
This logic is used in invalidation mode caches.
ClusteringDependentLogic.LocalLogic - Class in org.infinispan.interceptors.locking
This logic is used in local mode caches.
ClusteringDependentLogic.ReplicationLogic - Class in org.infinispan.interceptors.locking
This logic is used in replicated mode caches.
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
 
ClusterLoader - Class in org.infinispan.persistence.cluster
Cache loader that consults other members in the cluster for values.
ClusterLoader() - Constructor for class org.infinispan.persistence.cluster.ClusterLoader
 
ClusterLoaderConfiguration - Class in org.infinispan.configuration.cache
ClusterLoaderConfiguration.
ClusterLoaderConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, long) - Constructor for class org.infinispan.configuration.cache.ClusterLoaderConfiguration
 
ClusterLoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
 
ClusterLoaderConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
clusterModeWriteSkewCheck - Variable in class org.infinispan.container.EntryFactoryImpl
 
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.
ClusterRegistry<S,K,V> - Interface in org.infinispan.registry
A registry of scoped key-values available to all the nodes in the cluster.
ClusterRegistryImpl<S,K,V> - Class in org.infinispan.registry
Default implementation of the ClusterRegistry.
ClusterRegistryImpl() - Constructor for class org.infinispan.registry.ClusterRegistryImpl
 
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
 
ClusterViewListener() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl.ClusterViewListener
 
cm - Variable in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
codec - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
Codec - Interface in org.infinispan.client.hotrod.impl.protocol
A Hot Rod protocol encoder/decoder.
Codec10 - Class in org.infinispan.client.hotrod.impl.protocol
A Hot Rod encoder/decoder for version 1.0 of the protocol.
Codec10() - Constructor for class org.infinispan.client.hotrod.impl.protocol.Codec10
 
Codec11 - Class in org.infinispan.client.hotrod.impl.protocol
A Hot Rod encoder/decoder for version 1.1 of the protocol.
Codec11() - Constructor for class org.infinispan.client.hotrod.impl.protocol.Codec11
 
Codec12 - Class in org.infinispan.client.hotrod.impl.protocol
A Hot Rod encoder/decoder for version 1.2 of the protocol.
Codec12() - Constructor for class org.infinispan.client.hotrod.impl.protocol.Codec12
 
CodecFactory - Class in org.infinispan.client.hotrod.impl.protocol
Code factory.
CodecFactory() - Constructor for class org.infinispan.client.hotrod.impl.protocol.CodecFactory
 
CODENAME - Static variable in class org.infinispan.Version
 
coinToss - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
collate(Map<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.
CollectionFactory - Class in org.infinispan.commons.util
A factory for ConcurrentMaps.
CollectionFactory() - Constructor for class org.infinispan.commons.util.CollectionFactory
 
CollectionKeyFilter - Class in org.infinispan.persistence
Filter based on accepting/rejecting the keys that are present in a supplied collection.
CollectionKeyFilter(Collection) - Constructor for class org.infinispan.persistence.CollectionKeyFilter
 
CollectionKeyFilter(Collection, boolean) - Constructor for class org.infinispan.persistence.CollectionKeyFilter
 
Collector<K,V> - Interface in org.infinispan.distexec.mapreduce
OutputCollector is the intermediate key/value result data output collector given to each Mapper
Color - Enum in org.infinispan.cli.shell
 
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 - Interface in org.infinispan.cli.commands
 
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.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.totalorder.TotalOrderCommitCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.totalorder.TotalOrderRollbackCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedCommitCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
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.query.clustered.ClusteredQueryCommand
 
COMMAND_ID - Static variable in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
COMMAND_TIMEOUT_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CommandAwareRpcDispatcher - Class in org.infinispan.remoting.transport.jgroups
A JGroups RPC dispatcher that knows how to deal with ReplicableCommands.
CommandAwareRpcDispatcher(Channel, JGroupsTransport, ExecutorService, ExecutorService, InboundInvocationHandler, GlobalComponentRegistry, BackupReceiverRepository) - Constructor for class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
CommandBuffer - Interface in org.infinispan.cli
 
CommandBufferImpl - Class in org.infinispan.cli.impl
 
CommandBufferImpl() - Constructor for class org.infinispan.cli.impl.CommandBufferImpl
 
CommandFactory - Class in org.infinispan.query.impl
Remote commands factory implementation
CommandFactory() - Constructor for class org.infinispan.query.impl.CommandFactory
 
CommandInitializer - Class in org.infinispan.query.impl
Initializes query module remote commands
CommandInitializer() - Constructor for class org.infinispan.query.impl.CommandInitializer
 
CommandInterceptor - Class in org.infinispan.interceptors.base
This is the base class for all interceptors to extend, and implements the Visitor interface allowing it to intercept invocations on VisitableCommands.
CommandInterceptor() - Constructor for class org.infinispan.interceptors.base.CommandInterceptor
 
CommandRegistry - Class in org.infinispan.cli
 
CommandRegistry() - Constructor for class org.infinispan.cli.CommandRegistry
 
commandsBackendInitialized(String) - Method in interface org.infinispan.query.logging.Log
 
commandsBackendInitialized(String) - Method in class org.infinispan.query.logging.Log_$logger
 
commandsBackendInitialized$str() - Method in class org.infinispan.query.logging.Log_$logger
 
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.interceptors.distribution.L1NonTxInterceptor
 
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 - Class in org.infinispan.cli.commands.server
 
Commit() - Constructor for class org.infinispan.cli.commands.server.Commit
 
commit(DataContainer, Metadata) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
commit(DataContainer, Metadata) - Method in interface org.infinispan.container.entries.CacheEntry
Commits changes
commit(DataContainer, Metadata) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
commit(DataContainer, Metadata) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
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, Metadata) - 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.CacheWriterInterceptor
 
commitContextEntries(InvocationContext, FlagAffectedCommand, Metadata) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Metadata) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Metadata) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Metadata) - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
commitEntry(CacheEntry, Metadata, FlagAffectedCommand, InvocationContext) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
commitEntry(CacheEntry, Metadata, FlagAffectedCommand, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
commitEntry(CacheEntry, Metadata, FlagAffectedCommand, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
commitEntry(CacheEntry, Metadata, FlagAffectedCommand, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
commitEntry(CacheEntry, Metadata, FlagAffectedCommand, InvocationContext) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
commonPool() - Static method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns the common pool instance.
CommonsBufferSizePredictorAdapter - Class in org.infinispan.marshall
Deprecated.
CommonsBufferSizePredictorAdapter(BufferSizePredictor) - Constructor for class org.infinispan.marshall.CommonsBufferSizePredictorAdapter
Deprecated.
 
compare(T, T) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
 
compare(byte[], byte[]) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
compare(T, T) - Method in interface org.infinispan.commons.equivalence.Equivalence
Compares the two given objects for order.
compareAndSetForkJoinTaskTag(short, short) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Atomically conditionally sets the tag value for this task.
compareAndSetPendingCount(int, int) - Method in class org.infinispan.commons.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.NumericVersion
 
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
 
compatibility() - Method in class org.infinispan.configuration.cache.Configuration
 
compatibility() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
compatibility() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
CompatibilityModeConfiguration - Class in org.infinispan.configuration.cache
Compatibility mode configuration
CompatibilityModeConfigurationBuilder - Class in org.infinispan.configuration.cache
Compatibility mode configuration builder
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.AbstractCommand
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.client.Container
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.client.Help
 
complete(Context, ProcessedCommand, List<String>) - Method in interface org.infinispan.cli.commands.Command
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.server.Cache
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.server.Create
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.server.Info
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.server.Site
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.server.Stats
 
complete(Context, ProcessedCommand, List<String>) - Method in class org.infinispan.cli.commands.server.Upgrade
 
complete(CompleteOperation) - Method in class org.infinispan.cli.shell.Completer
 
complete(T) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Regardless of pending count, invokes CountedCompleter.onCompletion(org.infinispan.commons.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.commons.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.commons.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.
Completer - Class in org.infinispan.cli.shell
 
Completer(Context) - Constructor for class org.infinispan.cli.shell.Completer
 
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() - Constructor for class org.infinispan.factories.AbstractComponentRegistry.Component
 
Component() - Constructor for class org.infinispan.factories.TestDelayFactory.Component
 
COMPONENT_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
componentFailedToStop(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
componentFailedToStop(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
componentFailedToStop(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
componentFailedToStop(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
componentFailedToStop(Throwable) - Method in interface org.infinispan.util.logging.Log
 
componentFailedToStop(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
componentFailedToStop$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
componentFailedToStop$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
componentFailedToStop$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
componentFailedToStop$str() - Method in class org.infinispan.query.logging.Log_$logger
 
componentFailedToStop$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
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.
ComponentRegistryServiceProvider - Class in org.infinispan.query.backend
Simple wrapper to make the Cache ComponentRegistry available to the services managed by Hibernate Search
ComponentRegistryServiceProvider(ComponentRegistry) - Constructor for class org.infinispan.query.backend.ComponentRegistryServiceProvider
 
ComponentRegistryUtils - Class in org.infinispan.query.impl
Component registry utilities
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.
CompositeFilter - Class in org.infinispan.persistence
Allows AND-composing several filters.
CompositeFilter(AdvancedCacheLoader.KeyFilter...) - Constructor for class org.infinispan.persistence.CompositeFilter
 
compute() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
The main computation performed by this task.
compute(K, EquivalentConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
computeActualNumOwners(int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
computeExpectedSegments(int, int, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeGroup(T, String) - Method in interface org.infinispan.distribution.group.Grouper
Compute the group for a given key
computeIfAbsent(K, EquivalentConcurrentHashMapV8.Fun<? super K, ? extends V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
If the value for the specified key is present, attempts to compute a new mapping given the key and its current mapped value.
computeMaxSegmentsForMachine(int, double, Collection<TopologyInfo.Machine>, TopologyInfo.Machine, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForNode(int, double, Collection<Address>, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForRack(int, double, Collection<TopologyInfo.Rack>, TopologyInfo.Rack, TopologyInfo.Machine, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeMaxSegmentsForSite(int, double, Collection<TopologyInfo.Site>, TopologyInfo.Site, TopologyInfo.Rack, TopologyInfo.Machine, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeNewHashes(Transport, Log, int, int, short, int, int) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
computeNewHashes(Transport, Log, int, int, short, int, int) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec11
 
computeOrphan(Collection<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Check's if this transaction's originator is no longer part of the cluster (orphan transaction) and updates RecoveryAwareRemoteTransaction.isOrphan().
computeTotalCapacity(Collection<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
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.
concurrencyLevel(int) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
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.
ConcurrentWeakKeyHashMap<K,V> - Class in org.infinispan.commons.util.concurrent
An alternative weak-key ConcurrentMap which is similar to ConcurrentHashMap.
ConcurrentWeakKeyHashMap(int, float, int) - Constructor for class org.infinispan.commons.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.commons.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.commons.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.commons.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.commons.util.concurrent.ConcurrentWeakKeyHashMap
Creates a new map with the same mappings as the given map.
ConcurrentWeakKeyHashMap.ReusableIterator<E> - Interface in org.infinispan.commons.util.concurrent
 
config - Variable in class org.infinispan.CacheImpl
 
Config - Interface in org.infinispan.cli
 
config - Variable in class org.infinispan.context.AbstractInvocationContextFactory
 
config - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
ConfigImpl - Class in org.infinispan.cli.shell
ConfigImpl.
ConfigImpl(String) - Constructor for class org.infinispan.cli.shell.ConfigImpl
 
Configuration - Class in org.infinispan.client.hotrod.configuration
Configuration.
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_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
 
ConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
ConfigurationBuilder used to generate immutable Configuration objects to pass to the RemoteCacheManager.RemoteCacheManager(Configuration) constructor.
ConfigurationBuilder() - Constructor for class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
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.client.hotrod.configuration
ConfigurationChildBuilder.
ConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ConfigurationFor - Annotation Type in org.infinispan.commons.configuration
ConfigurationFor.
ConfigurationParser - Interface in org.infinispan.configuration.parsing
ConfigurationParser.
ConfigurationProperties - Class in org.infinispan.client.hotrod.impl
Encapsulate all config properties here
ConfigurationProperties() - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationProperties(String) - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationProperties(Properties) - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
Configurations - Class in org.infinispan.configuration.cache
Helper configuration methods.
ConfigurationUtils - Class in org.infinispan.commons.configuration
ConfigurationUtils.
configuratorError(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
configuratorError(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
configuratorError(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
configuratorError(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
configuratorError(Exception) - Method in interface org.infinispan.util.logging.Log
 
configuratorError(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorError$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
configuratorError$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
configuratorError$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
configuratorError$str() - Method in class org.infinispan.query.logging.Log_$logger
 
configuratorError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in interface org.infinispan.util.logging.Log
 
configuratorSAXError(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXError$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
configuratorSAXError$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
configuratorSAXError$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
configuratorSAXError$str() - Method in class org.infinispan.query.logging.Log_$logger
 
configuratorSAXError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in interface org.infinispan.util.logging.Log
 
configuratorSAXParseError(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXParseError$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
configuratorSAXParseError$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
configuratorSAXParseError$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
configuratorSAXParseError$str() - Method in class org.infinispan.query.logging.Log_$logger
 
configuratorSAXParseError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configure() - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
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
 
confirmRebalance(String, int, Throwable) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
confirmRebalanceOnNode(Address, int) - Method in class org.infinispan.topology.ClusterCacheStatus
 
Connect - Class in org.infinispan.cli.commands.client
 
Connect() - Constructor for class org.infinispan.cli.commands.client.Connect
 
connect(String) - Method in interface org.infinispan.cli.connection.Connection
 
connect(String) - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
CONNECT_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
connectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
Connection - Interface in org.infinispan.cli.connection
 
ConnectionFactory - Class in org.infinispan.cli.connection
 
ConnectionFactory() - Constructor for class org.infinispan.cli.connection.ConnectionFactory
 
connectionFactory() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
 
connectionFactory - Variable in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
connectionFactory(Class<C>) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
Use the specified ConnectionFactory to handle connection to the database
connectionFactory(C) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
Use the specified ConnectionFactoryConfigurationBuilder to configure connections to the database
ConnectionFactory - Class in org.infinispan.persistence.jdbc.connectionfactory
Defines the functionality a connection factory should implement.
ConnectionFactory() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
 
connectionFactoryClass() - Method in interface org.infinispan.persistence.jdbc.configuration.ConnectionFactoryConfiguration
 
connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
 
connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
 
ConnectionFactoryConfig - Class in org.infinispan.persistence.jdbc.connectionfactory
Contains configuration elements for a ConnectionFactory.
ConnectionFactoryConfig(String, String, String, String, String) - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
ConnectionFactoryConfig() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
ConnectionFactoryConfiguration - Interface in org.infinispan.persistence.jdbc.configuration
ConnectionFactoryConfiguration.
ConnectionFactoryConfigurationBuilder<T extends ConnectionFactoryConfiguration> - Interface in org.infinispan.persistence.jdbc.configuration
 
connectionInJndiNotFound(String) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
connectionInJndiNotFound(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
connectionInJndiNotFound$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
connectionPool() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
connectionPool() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
connectionPool() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
connectionPool() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Configures the connection pool
connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder.BinaryTableManipulationConfigurationBuilder
 
connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
connectionPool() - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationChildBuilder
Configures a connection pool to be used by this JDBC Cache Store to handle connections to the database
connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
connectionPool() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
connectionPool() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
connectionPool() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
connectionPool() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configures the connection pool
ConnectionPoolConfiguration - Class in org.infinispan.client.hotrod.configuration
ConnectionPoolConfiguration.
ConnectionPoolConfiguration - Class in org.infinispan.persistence.remote.configuration
 
ConnectionPoolConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
ConnectionPoolConfigurationBuilder.
ConnectionPoolConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
ConnectionPoolConfigurationBuilder.
connectionString() - Method in class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfiguration
 
connectionString(String) - Method in class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationBuilder
 
connectionTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
connectionTimeout() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
connectionTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
connectionTimeout(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
This property defines the maximum socket connect timeout before giving up connecting to the server.
connectionTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
connectionTimeout() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
connectionTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
connectionTimeout(long) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
This property defines the maximum socket connect timeout before giving up connecting to the server.
connectionUrl() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
connectionUrl(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
connectionUrl() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
 
connectionUrl(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
Connector - Interface in org.infinispan.cli.connection
Connector.
ConsistentHash - Interface in org.infinispan.client.hotrod.impl.consistenthash
Abstraction for the used consistent hash.
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.
consistentHashDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
consistentHashDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
consistentHashDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
consistentHashDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
consistentHashDeprecated() - Method in interface org.infinispan.util.logging.Log
 
consistentHashDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
consistentHashDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
consistentHashDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
consistentHashDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
consistentHashDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
consistentHashDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ConsistentHashFactory - Class in org.infinispan.client.hotrod.impl.consistenthash
Factory for ConsistentHash function.
ConsistentHashFactory() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
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.
consistentHashImpl(int, Class<? extends ConsistentHash>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
consistentHashImpl(int, String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
consistentHashImpl() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
consistentHashImpl(int) - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
consistentHashImpl(int, Class<? extends ConsistentHash>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
consistentHashImpl(int, String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
consistentHashImpl(int, Class<? extends ConsistentHash>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Defines the ConsistentHash implementation to use for the specified version.
consistentHashImpl(int, String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Defines the ConsistentHash implementation to use for the specified version.
ConsistentHashV1 - Class in org.infinispan.client.hotrod.impl.consistenthash
Version one consistent hash function based on MurmurHash2;
ConsistentHashV1(Random) - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
ConsistentHashV1() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
ConsistentHashV2 - Class in org.infinispan.client.hotrod.impl.consistenthash
Version 2 of the ConsistentHash function.
ConsistentHashV2() - Constructor for class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV2
 
ConsoleIOAdapter - Class in org.infinispan.cli.io
 
ConsoleIOAdapter(Console) - Constructor for class org.infinispan.cli.io.ConsoleIOAdapter
 
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.commons.util.Util
 
constructMessage(Buffer, Address, boolean, ResponseMode, boolean, boolean) - Static method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
Container - Class in org.infinispan.cli.commands.client
 
Container() - Constructor for class org.infinispan.cli.commands.client.Container
 
container - Variable in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
containRemoteTx(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
contains(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
 
contains(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
 
contains(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Returns true if this set contains the specified element.
contains(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Deprecated.
contains(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
contains(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
contains(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
contains(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
contains(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
contains(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
contains(Object) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList
 
contains(Object) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet
 
contains(Object) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
 
contains(Object) - Method in class org.infinispan.persistence.async.AsyncCacheLoader
 
contains(K) - Method in class org.infinispan.persistence.cli.CLInterfaceLoader
 
contains(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
contains(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
The base class implementation calls SingleFileStore.load(Object) for this, we can do better because we keep all keys in memory.
contains(Object) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
contains(Object) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
contains(Object) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
contains(Object) - Method in class org.infinispan.persistence.remote.RemoteStore
 
contains(K) - Method in interface org.infinispan.persistence.spi.CacheLoader
Returns true if the storage contains an entry associated with the given key.
contains(Object, TimeService) - Method in class org.infinispan.persistence.support.Bucket
 
contains(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
contains(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument (which is expected to be an array or a Collection) contains the given element.
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.ReadOnlyDataContainerBackedKeySet
 
CONTAINS_KEY_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
CONTAINS_KEY_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.ForwardingList
 
containsAll(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument (which is expected to be an array or a Collection) contains all of the the given elements, in any order.
containsAll(Collection) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument (which is expected to be an array or a Collection) contains all the elements of the given collection, in any order.
containsAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
containsAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
containsAny(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument (which is expected to be an array or a Collection) contains any of the the given elements.
containsAny(Collection) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument (which is expected to be an array or a Collection) contains any of the elements of the given collection.
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 class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
containsKey(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
containsKey(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
containsKey(Object) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
containsKey(Object) - Method in class org.infinispan.commons.util.WeakValueHashMap
 
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(S, K) - Method in interface org.infinispan.registry.ClusterRegistry
 
containsKey(S, K) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
containsKey(Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Tests if the specified object is a key in this table.
ContainsKeyOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "containsKey" operation as described in Hot Rod protocol specification.
ContainsKeyOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.ContainsKeyOperation
 
containsLocalModeFlag - Variable in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
containsLocalTx(Transaction) - Method in class org.infinispan.transaction.TransactionTable
Returns true if the given transaction is already registered with the transaction table.
containsLocalTx(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
containsPutForExternalRead - Variable in class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
containsValue(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
containsValue(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
containsValue(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
containsValue(Object) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
containsValue(Object) - Method in class org.infinispan.CacheImpl
 
containsValue(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
containsValue(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
containsValue(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
containsValue(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
containsValue(Object) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
containsValue(Object) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns true if this map maps one or more keys to the specified value.
contentType - Variable in class org.infinispan.remoting.MIMECacheEntry
The MIME Content type value, for example application/octet-stream.
Context - Interface in org.infinispan.cli
Context.
ContextImpl - Class in org.infinispan.cli.impl
ContextImpl.
ContextImpl(IOAdapter, CommandBuffer) - Constructor for class org.infinispan.cli.impl.ContextImpl
 
ContractAdaptorFactory - Class in org.infinispan.lucene.cacheloader
 
Control() - Constructor for class org.infinispan.factories.TestDelayFactory.Control
 
convert(Object[]) - Method in class org.infinispan.query.impl.ProjectionConverter
 
coordinator - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
copy() - Method in class org.infinispan.atomic.AtomicHashMap
 
copy() - Method in class org.infinispan.commands.tx.PrepareCommand
 
copy() - Method in interface org.infinispan.commons.io.ByteBuffer
Returns a new byte[] instance of size ByteBuffer.getLength() that contains all the bytes owned by this buffer.
copy() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
copy(InputStream, OutputStream, byte[]) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream.
copy(InputStream, OutputStream, int) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream.
copy(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream.
copyb(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
Copy all of the bytes from the input stream to the output stream wrapping streams in buffers as needed.
copyForUpdate(DataContainer) - Method in interface org.infinispan.container.entries.MVCCEntry
Makes internal copies of the entry for updates
copyForUpdate(DataContainer) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
copyForUpdate(DataContainer) - 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.
CoreImmutables - Class in org.infinispan.util
Factory for generating immutable type wrappers for core types.
CoreImmutables() - Constructor for class org.infinispan.util.CoreImmutables
 
couldNoInvalidateConnection(TcpTransport, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNoInvalidateConnection(TcpTransport, Exception) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNoInvalidateConnection$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotAcquireLockForEviction(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotAcquireLockForEviction(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotAcquireLockForEviction(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotAcquireLockForEviction(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotAcquireLockForEviction(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotAcquireLockForEviction(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotAcquireLockForEviction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotAcquireLockForEviction$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotAcquireLockForEviction$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotAcquireLockForEviction$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotAcquireLockForEviction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotAcquireSharedLock() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotAcquireSharedLock() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotAcquireSharedLock() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotAcquireSharedLock() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotAcquireSharedLock() - Method in interface org.infinispan.util.logging.Log
 
couldNotAcquireSharedLock() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotAcquireSharedLock$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotAcquireSharedLock$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotAcquireSharedLock$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotAcquireSharedLock$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotAcquireSharedLock$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotCompleteInjectedTransaction(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotCompleteInjectedTransaction(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotCompleteInjectedTransaction(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotCompleteInjectedTransaction(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotCompleteInjectedTransaction(Throwable) - Method in interface org.infinispan.util.logging.Log
 
couldNotCompleteInjectedTransaction(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotCompleteInjectedTransaction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotCompleteInjectedTransaction$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotCompleteInjectedTransaction$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotCompleteInjectedTransaction$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotCompleteInjectedTransaction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotDestroyC3p0ConnectionPool(String, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
couldNotDestroyC3p0ConnectionPool(String, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotDestroyC3p0ConnectionPool$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotExecuteCancellationLocally(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotExecuteCancellationLocally(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotExecuteCancellationLocally(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotExecuteCancellationLocally(String) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotExecuteCancellationLocally(String) - Method in interface org.infinispan.util.logging.Log
 
couldNotExecuteCancellationLocally(String) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotExecuteCancellationLocally$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotExecuteCancellationLocally$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotExecuteCancellationLocally$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotExecuteCancellationLocally$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotExecuteCancellationLocally$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFetchTransport(Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotFetchTransport(Exception) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotFetchTransport$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
couldNotFindAttribute(String) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFindAttribute$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotFindAttribute$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotFindAttribute$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotFindAttribute$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotFindAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFindDescriptionField() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotFindDescriptionField() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotFindDescriptionField() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotFindDescriptionField() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotFindDescriptionField() - Method in interface org.infinispan.util.logging.Log
 
couldNotFindDescriptionField() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFindDescriptionField$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotFindDescriptionField$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotFindDescriptionField$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotFindDescriptionField$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotFindDescriptionField$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFindPropertiesFile(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotFindPropertiesFile(String) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotFindPropertiesFile$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotInitializeModule(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInitializeModule(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInitializeModule(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInitializeModule(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInitializeModule(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInitializeModule(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInitializeModule$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInitializeModule$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInitializeModule$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInitializeModule$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInitializeModule$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInstantiaterTransformerClass(Class<?>, Exception) - Method in interface org.infinispan.query.logging.Log
 
couldNotInstantiaterTransformerClass(Class, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInstantiaterTransformerClass$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInstantiateTransactionManager(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInstantiateTransactionManager$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInstantiateTransactionManager$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInstantiateTransactionManager$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInstantiateTransactionManager$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInstantiateTransactionManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in interface org.infinispan.util.logging.Log
 
couldNotInterruptThread(UUID) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInterruptThread$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInterruptThread$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInterruptThread$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInterruptThread$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInterruptThread$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
couldNotInvokeSetOnAttribute(String, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInvokeSetOnAttribute$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotInvokeSetOnAttribute$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotInvokeSetOnAttribute$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotInvokeSetOnAttribute$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotInvokeSetOnAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotLoadModuleAtUrl(URL, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotLoadModuleAtUrl$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotLoadModuleAtUrl$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotLoadModuleAtUrl$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotLoadModuleAtUrl$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotLoadModuleAtUrl$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in interface org.infinispan.util.logging.Log
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRegisterObjectName$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotRegisterObjectName$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotRegisterObjectName$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotRegisterObjectName$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotRegisterObjectName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotReleaseConnection(TcpTransport, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotReleaseConnection(TcpTransport, Exception) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotReleaseConnection$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
couldNotResolveConfigurationSchema(String, String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotResolveConfigurationSchema(String, String, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotResolveConfigurationSchema(String, String, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotResolveConfigurationSchema(String, String, String) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotResolveConfigurationSchema(String, String, String) - Method in interface org.infinispan.util.logging.Log
 
couldNotResolveConfigurationSchema(String, String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotResolveConfigurationSchema$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotResolveConfigurationSchema$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotResolveConfigurationSchema$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotResolveConfigurationSchema$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotResolveConfigurationSchema$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction$str() - Method in class org.infinispan.query.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotWalkDirectory(String, PersistenceException) - Method in interface org.infinispan.lucene.logging.Log
 
couldNotWalkDirectory(String, PersistenceException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
couldNotWalkDirectory$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
count(AdvancedCacheLoader, AdvancedCacheLoader.KeyFilter) - Static method in class org.infinispan.persistence.PersistenceUtil
 
CountedCompleter<T> - Class in org.infinispan.commons.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.commons.util.concurrent.jdk8backported.CountedCompleter
Creates a new CountedCompleter with the given completer and initial pending count.
CountedCompleter(CountedCompleter<?>) - Constructor for class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.CountedCompleter
Creates a new CountedCompleter with no completer and an initial pending count of zero.
counter - Static variable in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
CQCreateEagerQuery - Class in org.infinispan.query.clustered.commandworkers
CQCreateEagerQuery.
CQCreateEagerQuery() - Constructor for class org.infinispan.query.clustered.commandworkers.CQCreateEagerQuery
 
CQCreateLazyQuery - Class in org.infinispan.query.clustered.commandworkers
CQCreateLazyQuery.
CQCreateLazyQuery() - Constructor for class org.infinispan.query.clustered.commandworkers.CQCreateLazyQuery
 
CQGetResultSize - Class in org.infinispan.query.clustered.commandworkers
CQGetResultSize.
CQGetResultSize() - Constructor for class org.infinispan.query.clustered.commandworkers.CQGetResultSize
 
CQKillLazyIterator - Class in org.infinispan.query.clustered.commandworkers
CQKillLazyIterator.
CQKillLazyIterator() - Constructor for class org.infinispan.query.clustered.commandworkers.CQKillLazyIterator
 
CQLazyFetcher - Class in org.infinispan.query.clustered.commandworkers
CQLazyFetcher.
CQLazyFetcher() - Constructor for class org.infinispan.query.clustered.commandworkers.CQLazyFetcher
 
Create - Class in org.infinispan.cli.commands.server
 
Create() - Constructor for class org.infinispan.cli.commands.server.Create
 
create() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
create() - Method in interface org.infinispan.commons.configuration.Builder
Create the configuration bean
create(T) - Static method in class org.infinispan.commons.util.ByRef
 
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.ClusteringConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
 
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.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.LockingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
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, Metadata) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(Object, Object, Metadata, long, long) - Method in interface org.infinispan.container.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(Object, Object, Metadata, long, long, 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, Metadata) - 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, Metadata, long, long, long, long) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(Object, Object, Metadata, long, long) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Create a new consistent hash instance.
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
create() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
 
create() - Method in interface org.infinispan.lucene.directory.BuildContext
Creates a Directory instance
create() - Method in class org.infinispan.lucene.impl.DirectoryBuilderImpl
 
create() - Method in class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
create(Object) - Static method in class org.infinispan.remoting.responses.SuccessfulResponse
 
createAndWire(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
 
createAsyncWriter(CacheWriter) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
createBackend(String, Properties, WorkerBuildContext) - Method in class org.infinispan.query.indexmanager.InfinispanIndexManager
 
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.metadata.MetadataMortalCacheEntry
 
created - Variable in class org.infinispan.container.entries.MortalCacheEntry
 
created - Variable in class org.infinispan.container.entries.MortalCacheValue
 
created - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
created() - Method in interface org.infinispan.metadata.InternalMetadata
 
created() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
createDirectoryProvider(String, Properties, WorkerBuildContext) - Method in class org.infinispan.query.indexmanager.InfinispanIndexManager
 
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
 
createEagerIterator(HSQuery, Cache<?, ?>) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
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.commons.marshall.jboss.JBossExternalizerAdapter
 
createFilteredEntrySet(Set<InternalCacheEntry>, InvocationContext, TimeService, InternalEntryFactory) - Static method in class org.infinispan.commands.read.EntrySetCommand
 
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.InvocationContextFactory
If we are in a tx scope this will return an TxInvocationContext.
createInvocationContext(Transaction) - Method in interface org.infinispan.context.InvocationContextFactory
Creates an invocation context
createInvocationContext(boolean, int) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createInvocationContext(Transaction) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createInvocationContext(boolean, int) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createInvocationContext(Transaction) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createLazyIterator(HSQuery, Cache<?, ?>, UUID) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
createMap() - Method in class org.infinispan.commons.util.WeakValueHashMap
Create map.
createMarshalledValue(Object, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
createMarshaller(MarshallingConfiguration) - Method in class org.infinispan.commons.marshall.jboss.JBossMarshallerFactory
 
createNewEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
 
createNewFile() - Method in class org.infinispan.io.GridFile
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
createNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createOnStart() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
createOnStart(boolean) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Determines whether database tables should be created by the store on startup
createOutput(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
createPerEntityTypeWorks(Class<T>, WorkType) - Method in interface org.infinispan.query.backend.SearchWorkCreator
Creates a collection of Work instances that Hibernate-Search should perform for all the entities of the given entity type.
createPerEntityTypeWorks(Class<T>, WorkType) - Method in class org.infinispan.query.impl.DefaultSearchWorkCreator
 
createPerEntityWorks(T, Serializable, WorkType) - Method in interface org.infinispan.query.backend.SearchWorkCreator
Creates a collection of Work instances that Hibernate-Search should perform for the given entity
createPerEntityWorks(T, Serializable, WorkType) - Method in class org.infinispan.query.impl.DefaultSearchWorkCreator
 
createPushStateTask() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
 
createReducePart(ReduceCommand<KOut, VOut>, Address, String) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
createRemoteInvocationContext(Address) - Method in interface org.infinispan.context.InvocationContextFactory
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in class org.infinispan.context.AbstractInvocationContextFactory
 
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in interface org.infinispan.context.InvocationContextFactory
As InvocationContextFactory.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.InvocationContextFactory
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createSingleKeyNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createTable(Connection) - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
createTaskMapPart(MapCombineCommand<KIn, VIn, KOut, VOut>, Address, boolean) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
createTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
createTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
createUnmarshaller(MarshallingConfiguration) - Method in class org.infinispan.commons.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
 
createWrappedEntry(Object, CacheEntry, InvocationContext, Metadata, boolean, boolean, boolean) - Method in class org.infinispan.container.EntryFactoryImpl
 
createWrappedEntry(Object, CacheEntry, InvocationContext, Metadata, boolean, boolean, boolean) - Method in class org.infinispan.container.IncrementalVersionableEntryFactoryImpl
 
ctx - Variable in class org.infinispan.persistence.file.SingleFileStore
 
ctx - Variable in class org.infinispan.persistence.remote.RemoteStore
 
ctx - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
 
ctx - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
 
current() - Static method in class org.infinispan.commons.util.concurrent.jdk7backported.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.
CURRENT_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of entries currently in the Hot Rod server
currentMillisFromNanotime() - Static method in class org.infinispan.commons.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
 
CustomBackupPolicyInvoker(String, CustomFailurePolicy, Transaction) - Constructor for class org.infinispan.xsite.BackupSenderImpl.CustomBackupPolicyInvoker
 
CustomFailurePolicy<K,V> - Interface in org.infinispan.xsite
Used for implementing custom policies in case of communication failures with a remote site.
customInterceptorExpectsInjection(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
customInterceptorExpectsInjection(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
customInterceptorExpectsInjection(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
customInterceptorExpectsInjection(String) - Method in class org.infinispan.query.logging.Log_$logger
 
customInterceptorExpectsInjection(String) - Method in interface org.infinispan.util.logging.Log
 
customInterceptorExpectsInjection(String) - Method in class org.infinispan.util.logging.Log_$logger
 
customInterceptorExpectsInjection$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
customInterceptorExpectsInjection$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
customInterceptorExpectsInjection$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
customInterceptorExpectsInjection$str() - Method in class org.infinispan.query.logging.Log_$logger
 
customInterceptorExpectsInjection$str() - Method in class org.infinispan.util.logging.Log_$logger
 
customInterceptorMissingClass() - Method in class org.infinispan.lucene.logging.Log_$logger
 
customInterceptorMissingClass() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
customInterceptorMissingClass() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
customInterceptorMissingClass() - Method in class org.infinispan.query.logging.Log_$logger
 
customInterceptorMissingClass() - Method in interface org.infinispan.util.logging.Log
 
customInterceptorMissingClass() - Method in class org.infinispan.util.logging.Log_$logger
 
customInterceptorMissingClass$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
customInterceptorMissingClass$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
customInterceptorMissingClass$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
customInterceptorMissingClass$str() - Method in class org.infinispan.query.logging.Log_$logger
 
customInterceptorMissingClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
CustomQueryCommand - Interface in org.infinispan.query.impl
Custom commands from the Query module should implement this interface to fetch needed components.

D

data - Variable in class org.infinispan.io.GridFilesystem
 
data - Variable in class org.infinispan.remoting.MIMECacheEntry
The payload.
databaseType() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
databaseType(DatabaseType) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
Specifies the type of the underlying database.
databaseType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
databaseType(DatabaseType) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Specifies the type of the underlying database.
DatabaseType - Enum in org.infinispan.persistence.jdbc
Supported database dialects for the JDBC cache stores
databaseType - Variable in class org.infinispan.persistence.jdbc.TableManipulation
 
dataColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dataColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The name of the database column used to store the entries
dataColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dataColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The type of the database column used to store the entries
DataCommand - Interface in org.infinispan.commands
Commands of this type manipulate data in the cache.
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.distribution.L1NonTxInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.EntryWrappingInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
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.
dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder.BinaryTableManipulationConfigurationBuilder
 
dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
dataSource() - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationChildBuilder
Configures a DataSource to be used by this JDBC Cache Store to handle connections to the database
dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
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.core.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.
DebuggingExceptionListener() - Constructor for class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
DECODE - Static variable in class org.infinispan.commons.util.Base64
Specify decoding.
decode(byte[], int, int) - Static method in class org.infinispan.commons.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.commons.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decodeFromFile(String) - Static method in class org.infinispan.commons.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeToFile(String, String) - Static method in class org.infinispan.commons.util.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.LongAdder
Equivalent to add(-1).
decrementPendingCountUnlessZero() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
If the pending count is nonzero, (atomically) decrements it.
DEF_CLASS_COUNT - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
DEF_INSTANCE_COUNT - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
DEFAULT_BATCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.TableManipulation
 
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.lucene.impl.DirectoryBuilderImpl
Used as default chunk size: each Lucene index segment is split into smaller parts having a default size in bytes as defined here
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
Used as default chunk size, can be overridden at construction time.
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.util.stream.Streams
The default buffer size that will be used for buffered operations.
DEFAULT_CACHE_NAME - Static variable in interface org.infinispan.api.BasicCacheContainer
Deprecated.
 
DEFAULT_CACHE_NAME - Static variable in class org.infinispan.client.hotrod.RemoteCacheManager
 
DEFAULT_CACHE_NAME - Static variable in interface org.infinispan.commons.api.BasicCacheContainer
 
DEFAULT_CACHE_NAME_BYTES - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
DEFAULT_CONNECT_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_CONSISTENT_HASH - Static variable in interface org.infinispan.marshall.core.Ids
 
DEFAULT_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.core.Ids
 
DEFAULT_DOUBLING_SIZE - Static variable in class org.infinispan.commons.io.ExposedByteArrayOutputStream
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.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
Deprecated.
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
DEFAULT_EXECUTOR_FACTORY_POOL_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_EXECUTOR_FACTORY_QUEUE_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_FETCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.TableManipulation
 
DEFAULT_HOTROD_PORT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_INDENT - Static variable in class org.infinispan.cli.shell.Man2Ansi
 
DEFAULT_JGROUPS_CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
DEFAULT_KEY_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.configuration.global.GlobalConfiguration
Default replication version, from Version.getVersionShort().
DEFAULT_PROTOCOL_VERSION - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_RECOVERY_INFO_CACHE - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
DEFAULT_SO_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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
 
DEFAULT_VALUE_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DefaultAsyncExecutorFactory - Class in org.infinispan.client.hotrod.impl.async
Default implementation for org.infinispan.executors.ExecutorFactory based on an ThreadPoolExecutor.
DefaultAsyncExecutorFactory() - Constructor for class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
DefaultCacheManager - Class in org.infinispan.manager
A CacheManager is the primary mechanism for retrieving a Cache instance, and is often used as a starting point to using the Cache.
DefaultCacheManager() - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a default instance of the CacheManager, using configuration defaults.
DefaultCacheManager(boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a default instance of the CacheManager, using configuration defaults.
DefaultCacheManager(Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the default configuration passed in.
DefaultCacheManager(Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the default configuration passed in.
DefaultCacheManager(GlobalConfiguration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the global configuration passed in, and system defaults for the default named cache configuration.
DefaultCacheManager(GlobalConfiguration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the global configuration passed in, and system defaults for the default named cache configuration.
DefaultCacheManager(GlobalConfiguration, Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the global and default configurations passed in.
DefaultCacheManager(GlobalConfiguration, Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the global and default configurations passed in.
DefaultCacheManager(String) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the configuration file name passed in.
DefaultCacheManager(String, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the configuration file name passed in.
DefaultCacheManager(InputStream) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(InputStream, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(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>, Map<Address, Float>, List<Address>[]) - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHash
 
DefaultConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
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.Externalizer - Class in org.infinispan.distribution.ch
 
DefaultContextClassResolver - Class in org.infinispan.commons.marshall.jboss
This class refines ContextClassLoader to add a default class loader.
DefaultContextClassResolver(ClassLoader) - Constructor for class org.infinispan.commons.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, Equivalence, Equivalence) - Constructor for class org.infinispan.container.DefaultDataContainer
 
DefaultDataContainer(int, int, EvictionStrategy, EvictionThreadPolicy, Equivalence, Equivalence) - 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.
DefaultFileLookup() - Constructor for class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
defaultForkJoinWorkerThreadFactory - Static variable in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Creates a new ForkJoinWorkerThread.
defaultLifespan - Variable in class org.infinispan.CacheSupport
 
defaultLifespan - Variable in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
DefaultMapReduceTaskLifecycle - Class in org.infinispan.distexec.mapreduce.spi
 
DefaultMapReduceTaskLifecycle() - Constructor for class org.infinispan.distexec.mapreduce.spi.DefaultMapReduceTaskLifecycle
 
DefaultMassIndexerProgressMonitor - Class in org.infinispan.query.impl.massindex
 
DefaultMassIndexerProgressMonitor(TimeService) - Constructor for class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
Logs progress of indexing job every 50 documents written.
DefaultMassIndexerProgressMonitor(int, TimeService) - Constructor for class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
Logs progress of indexing job every logAfterNumberOfDocuments documents written.
defaultMaxIdleTime - Variable in class org.infinispan.CacheSupport
 
defaultMaxIdleTime - Variable in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
defaultMetadata - Variable in class org.infinispan.CacheImpl
 
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
 
DefaultSearchWorkCreator<T> - Class in org.infinispan.query.impl
 
DefaultSearchWorkCreator() - Constructor for class org.infinispan.query.impl.DefaultSearchWorkCreator
 
defaultSynchronous - Variable in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
DefaultTimeService - Class in org.infinispan.util
The default implementation of TimeService.
DefaultTimeService() - Constructor for class org.infinispan.util.DefaultTimeService
 
DefaultTransformer - Class in org.infinispan.query.impl
Warning, slow as a dog, uses serialization to get a byte representation of a class.
DefaultTransformer() - Constructor for class org.infinispan.query.impl.DefaultTransformer
 
defaultTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
DefaultTwoWayKey2StringMapper - Class in org.infinispan.persistence.keymappers
Default implementation for TwoWayKey2StringMapper that knows how to handle all primitive wrapper keys and Strings.
DefaultTwoWayKey2StringMapper() - Constructor for class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
defensive() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
Store as binary configuration is always defensive now.
defensive(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
Store as binary configuration is always defensive now.
DeferredReturnFuture<V> - Class in org.infinispan.commons.util.concurrent
This is a notifying and notifiable future whose return value is not known at construction time.
DeferredReturnFuture() - Constructor for class org.infinispan.commons.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.DefaultCacheManager
 
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
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
Defines a named cache's configuration using the following algorithm:

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

defineMappings(Cache, SearchMapping) - Method in interface org.infinispan.query.spi.ProgrammaticSearchMappingProvider
 
delegate - Variable in class org.infinispan.atomic.AtomicHashMap
 
delegate() - Method in class org.infinispan.commons.util.EnumerationList
 
delegate() - Method in class org.infinispan.commons.util.ForwardingList
 
DelegatingCacheLoader - Class in org.infinispan.persistence.support
 
DelegatingCacheLoader(CacheLoader) - Constructor for class org.infinispan.persistence.support.DelegatingCacheLoader
 
DelegatingCacheWriter - Class in org.infinispan.persistence.support
 
DelegatingCacheWriter(CacheWriter) - Constructor for class org.infinispan.persistence.support.DelegatingCacheWriter
 
delete() - Method in class org.infinispan.io.GridFile
 
delete(Object) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
delete(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
 
delete(Object) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
delete(Object) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
delete(Object) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
delete(Object) - Method in class org.infinispan.persistence.remote.RemoteStore
 
delete(K) - Method in interface org.infinispan.persistence.spi.CacheWriter
 
delete(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
delete(Object) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
 
deleteFile(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
deleteFileName(String) - Method in class org.infinispan.lucene.impl.FileListOperations
Deleted a file from the list of files actively part of the index
deleteFromAllStores(Object, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
deleteFromAllStores(Object, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
deleteOnExit() - Method in class org.infinispan.io.GridFile
 
deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
Deletes or releases a read-lock for the specified filename, so that if it was marked as deleted and no other InfinispanIndexInput instances are reading from it, then it will be effectively deleted.
deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
It will release a previously acquired readLock, or if no readLock was acquired it will mark the file to be deleted as soon as all pending locks are releases.
deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
doesn't do anything
deleteOrReleaseReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
It will release a previously acquired readLock, or if no readLock was acquired it will mark the file to be deleted as soon as all pending locks are releases.
delistResource(XAResource, int) - Method in class org.infinispan.transaction.tm.DummyTransaction
De-list an XA resource from this transaction.
delta() - Method in class org.infinispan.atomic.AtomicHashMap
 
Delta - Interface in org.infinispan.atomic
Represents changes made to a DeltaAware implementation.
delta() - Method in interface org.infinispan.atomic.DeltaAware
Extracts changes made to implementations, in an efficient format that can easily and cheaply be serialized and deserialized.
DELTA_COMPOSITE_KEY - Static variable in interface org.infinispan.marshall.core.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
 
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 class org.infinispan.lucene.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration() - Method in class org.infinispan.query.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration() - Method in interface org.infinispan.util.logging.Log
 
deprecatedLoaderAsStoreConfiguration() - Method in class org.infinispan.util.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration$str() - Method in class org.infinispan.query.logging.Log_$logger
 
deprecatedLoaderAsStoreConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
destroy() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
destroy() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
destroy() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
destroyLazyQuery(Cache<?, ?>, UUID) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
destroyObject(SocketAddress, TcpTransport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
detectedLuceneVersion(int) - Method in interface org.infinispan.lucene.logging.Log
 
detectedLuceneVersion(int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
detectedLuceneVersion$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
detectScope(Class<?>) - Static method in class org.infinispan.factories.scopes.ScopeDetector
 
determineTypeConverter(Set<Flag>) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
Subclasses need to return a TypeConverter instance that is appropriate for a cache operation with the specified flags.
determineTypeConverter(Set<Flag>) - Method in class org.infinispan.interceptors.compat.TypeConverterInterceptor
 
difference(Set<E>, Set<E>) - Static method in class org.infinispan.commons.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
 
DirectoryBuilder - Class in org.infinispan.lucene.directory
Builder class to create instances of the Directory implementation which stored data in the data grid.
DirectoryBuilderImpl - Class in org.infinispan.lucene.impl
 
DirectoryBuilderImpl(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.impl.DirectoryBuilderImpl
 
directoryCannotBeCreated(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
directoryCannotBeCreated(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
directoryCannotBeCreated(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
directoryCannotBeCreated(String) - Method in class org.infinispan.query.logging.Log_$logger
 
directoryCannotBeCreated(String) - Method in interface org.infinispan.util.logging.Log
 
directoryCannotBeCreated(String) - Method in class org.infinispan.util.logging.Log_$logger
 
directoryCannotBeCreated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
directoryCannotBeCreated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
directoryCannotBeCreated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
directoryCannotBeCreated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
directoryCannotBeCreated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
DirectoryExtensions - Interface in org.infinispan.lucene.impl
Some additional methods we add to our Directory implementations, mostly for reporting and testing reasons.
DirectoryV3Adaptor - Class in org.infinispan.lucene.cacheloader
 
DirectoryV3Adaptor(Directory) - Constructor for class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
DirectoryV4Adaptor - Class in org.infinispan.lucene.cacheloader
 
DirectoryV4Adaptor(Directory) - Constructor for class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
disable() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Disables the SSL support
disable() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
Disables compatibility mode between embedded.
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.
disabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Disable grouping support so that Group annotations are not used and any configured groupers will not be be invoked
disableFullTextFilter(String) - Method in interface org.infinispan.query.CacheQuery
Disable a given filter by its name.
disableFullTextFilter(String) - Method in class org.infinispan.query.impl.CacheQueryImpl
Disable a given filter by its name.
disableInterceptor() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
disableInterceptor() - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
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.
disableStore(String) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
disableStore(String) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Marks the given storage as disabled.
disableStore(String) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
Disconnect - Class in org.infinispan.cli.commands.client
 
Disconnect() - Constructor for class org.infinispan.cli.commands.client.Disconnect
 
disconnect() - Method in interface org.infinispan.cli.Context
 
disconnect() - Method in class org.infinispan.cli.impl.ContextImpl
 
disconnectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
disconnectJGroups() - Method in class org.infinispan.lucene.logging.Log_$logger
 
disconnectJGroups() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
disconnectJGroups() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
disconnectJGroups() - Method in class org.infinispan.query.logging.Log_$logger
 
disconnectJGroups() - Method in interface org.infinispan.util.logging.Log
 
disconnectJGroups() - Method in class org.infinispan.util.logging.Log_$logger
 
disconnectJGroups$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
disconnectJGroups$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
disconnectJGroups$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
disconnectJGroups$str() - Method in class org.infinispan.query.logging.Log_$logger
 
disconnectJGroups$str() - Method in class org.infinispan.util.logging.Log_$logger
 
disconnectSource(Cache<Object, Object>) - Method in class org.infinispan.persistence.cli.upgrade.CLInterfaceTargetMigrator
 
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
 
DistCacheWriterInterceptor - Class in org.infinispan.interceptors
Cache store interceptor specific for the distribution and replication cache modes.
DistCacheWriterInterceptor() - Constructor for class org.infinispan.interceptors.DistCacheWriterInterceptor
 
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
 
DistributedExecutorService - Interface in org.infinispan.distexec
An ExecutorService that provides methods to submit tasks for execution on a cluster of Infinispan nodes.
DistributedIterator - Class in org.infinispan.query.clustered
DistributedIterator.
DistributedIterator(Sort, int, int, int, int, HashMap<UUID, ClusteredTopDocs>, AdvancedCache<?, ?>) - Constructor for class org.infinispan.query.clustered.DistributedIterator
 
DistributedLazyIterator - Class in org.infinispan.query.clustered
DistributedLazyIterator.
DistributedLazyIterator(Sort, int, int, int, int, UUID, HashMap<UUID, ClusteredTopDocs>, ExecutorService, AdvancedCache<?, ?>) - Constructor for class org.infinispan.query.clustered.DistributedLazyIterator
 
DistributedSegmentReadLocker - Class in org.infinispan.lucene.readlocks
DistributedSegmentReadLocker stores reference counters in the cache to keep track of the number of clients still needing to be able to read a segment.
DistributedSegmentReadLocker(Cache<Object, Integer>, Cache<?, ?>, Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
 
DistributedSegmentReadLocker(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
 
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
 
DistributionLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
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 class org.infinispan.lucene.logging.Log_$logger
 
distributionManagerNotJoined() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
distributionManagerNotJoined() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
distributionManagerNotJoined() - Method in class org.infinispan.query.logging.Log_$logger
 
distributionManagerNotJoined() - Method in interface org.infinispan.util.logging.Log
 
distributionManagerNotJoined() - Method in class org.infinispan.util.logging.Log_$logger
 
distributionManagerNotJoined$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
distributionManagerNotJoined$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
distributionManagerNotJoined$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
distributionManagerNotJoined$str() - Method in class org.infinispan.query.logging.Log_$logger
 
distributionManagerNotJoined$str() - Method in class org.infinispan.util.logging.Log_$logger
 
distributionManagerNotStarted() - Method in class org.infinispan.lucene.logging.Log_$logger
 
distributionManagerNotStarted() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
distributionManagerNotStarted() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
distributionManagerNotStarted() - Method in class org.infinispan.query.logging.Log_$logger
 
distributionManagerNotStarted() - Method in interface org.infinispan.util.logging.Log
 
distributionManagerNotStarted() - Method in class org.infinispan.util.logging.Log_$logger
 
distributionManagerNotStarted$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
distributionManagerNotStarted$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
distributionManagerNotStarted$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
distributionManagerNotStarted$str() - Method in class org.infinispan.query.logging.Log_$logger
 
distributionManagerNotStarted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
dm - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
doAddBackupOwners(DefaultConsistentHashFactory.Builder) - 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
 
docIndex - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
doConnectionFactoryInitialization(ConnectionFactory) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
documentsAdded(long) - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
documentsBuilt(int) - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
domain() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
DONT_BREAK_LINES - Static variable in class org.infinispan.commons.util.Base64
Don't break lines when encoding (violates strict Base64 specification)
DOUBLE - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
doubleValue() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
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.commons.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.
driverClass() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
driverClass(Class<? extends Driver>) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
driverClass(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
driverClass() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
 
driverClass(Class<? extends Driver>) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
driverClass(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
dropOnExit() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dropOnExit(boolean) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Determines whether database tables should be dropped by the store on shutdown
dropTable(Connection) - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
dryRunNextServer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
Returns same value as RoundRobinBalancingStrategy.nextServer() without modifying indexes/state.
DummyBaseTransactionManager - Class in org.infinispan.transaction.tm
 
DummyBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
DummyNoXaXid - Class in org.infinispan.transaction.tm
Xid to be used when no XAResource enlistment takes place.
DummyNoXaXid() - Constructor for class org.infinispan.transaction.tm.DummyNoXaXid
 
DummyTransaction - Class in org.infinispan.transaction.tm
 
DummyTransaction(DummyBaseTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyTransaction
 
DummyTransactionManager - Class in org.infinispan.transaction.tm
Simple transaction manager implementation that maintains transaction state in memory only.
DummyTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyTransactionManager
 
DummyTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Returns an instance of DummyTransactionManager.
DummyTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
DummyUserTransaction - Class in org.infinispan.transaction.tm
 
DummyUserTransaction(DummyTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyUserTransaction
 
DummyXid - Class in org.infinispan.transaction.tm
Implementation of Xid.
DummyXid(UUID) - Constructor for class org.infinispan.transaction.tm.DummyXid
 
dumpStream() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
dumpStream() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
duplicateAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting that an attribute of a given name has already been declared in this scope.
duplicateCollection(Collection<E>) - Static method in class org.infinispan.commons.util.ObjectDuplicator
 
duplicateExternalizerIdFound(int, Class, String, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
duplicateExternalizerIdFound(int, Class, String, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
duplicateExternalizerIdFound(int, Class, String, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
duplicateExternalizerIdFound(int, Class, String, int) - Method in class org.infinispan.query.logging.Log_$logger
 
duplicateExternalizerIdFound(int, Class<?>, String, int) - Method in interface org.infinispan.util.logging.Log
 
duplicateExternalizerIdFound(int, Class, String, int) - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateExternalizerIdFound$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
duplicateExternalizerIdFound$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
duplicateExternalizerIdFound$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
duplicateExternalizerIdFound$str() - Method in class org.infinispan.query.logging.Log_$logger
 
duplicateExternalizerIdFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateMap(Map<K, V>) - Static method in class org.infinispan.commons.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.commons.util.ObjectDuplicator
 

E

EagerIterator - Class in org.infinispan.query.impl
This is the implementation class for the interface ResultIterator.
EagerIterator(List<EntityInfo>, QueryResultLoader, int) - Constructor for class org.infinispan.query.impl.EagerIterator
 
eagerLockingSingleNode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated.
starting with Infinispan 5.1 single node locking is used by default
eagerLockingSingleNode(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Deprecated.
starting with Infinispan 5.1 single node locking is used by default
echo(Shell, String) - Static method in class org.infinispan.cli.shell.Prompt
 
Element - Enum in org.infinispan.configuration.parsing
An enumeration of all the recognized XML element local names, by name.
Element - Enum in org.infinispan.persistence.cli.configuration
An enumeration of all the recognized XML element local names for the CLInterfaceLoader
Element - Enum in org.infinispan.persistence.jdbc.configuration
An enumeration of all the recognized XML element local names for the JDBC cache stores
Element - Enum in org.infinispan.persistence.remote.configuration
An enumeration of all the recognized XML element local names for the RemoteStore
elements() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns an enumeration of the values in this table.
elements() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns an enumeration of the values in this table.
elements() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns an enumeration of the values in this table.
EMBEDDED_METADATA - Static variable in interface org.infinispan.marshall.core.Ids
 
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
 
EmbeddedContextClassResolver(ClassLoader, InvocationContextContainer) - Constructor for class org.infinispan.marshall.core.JBossMarshaller.EmbeddedContextClassResolver
 
EmbeddedLuceneQueryFactory - Class in org.infinispan.query.dsl.embedded.impl
 
EmbeddedLuceneQueryFactory(SearchManager, EntityNamesResolver) - Constructor for class org.infinispan.query.dsl.embedded.impl.EmbeddedLuceneQueryFactory
 
EmbeddedMetadata - Class in org.infinispan.metadata
Metadata class for embedded caches.
EmbeddedMetadata.Builder - Class in org.infinispan.metadata
 
EmbeddedMetadata.Externalizer - Class in org.infinispan.metadata
 
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.commons.util.Util
 
EMPTY_CLASS_ARRAY - Static variable in class org.infinispan.commons.util.ReflectionUtil
 
EMPTY_INJECT_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
EMPTY_LIST - Static variable in interface org.infinispan.commons.marshall.Ids
 
EMPTY_MAP - Static variable in interface org.infinispan.commons.marshall.Ids
 
EMPTY_OBJECT_ARRAY - Static variable in class org.infinispan.commons.util.Util
 
EMPTY_PRIORITIZED_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
EMPTY_SET - Static variable in interface org.infinispan.commons.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
 
emptyEntryMap - Variable in class org.infinispan.context.impl.LocalTxInvocationContext
 
emptyList() - Static method in class org.infinispan.commons.util.InfinispanCollections
Returns the empty list (immutable).
EmptyList() - Constructor for class org.infinispan.commons.util.InfinispanCollections.EmptyList
 
EmptyListExternalizer() - Constructor for class org.infinispan.commons.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
emptyMap() - Static method in class org.infinispan.commons.util.InfinispanCollections
Returns the empty map (immutable).
EmptyMap() - Constructor for class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
EmptyMapExternalizer() - Constructor for class org.infinispan.commons.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
emptySet() - Static method in class org.infinispan.commons.util.InfinispanCollections
Returns the empty set (immutable).
EmptySet() - Constructor for class org.infinispan.commons.util.InfinispanCollections.EmptySet
 
EmptySetExternalizer() - Constructor for class org.infinispan.commons.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
enable() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Enables the SSL support
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.CompatibilityModeConfigurationBuilder
Enables compatibility mode between embedded and different remote endpoints (Hot Rod, Memcached, REST...etc).
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
 
enableClasses(Class<?>[]) - Method in class org.infinispan.query.backend.QueryInterceptor
 
enableClasses(Set<Class>) - Method in class org.infinispan.query.backend.QueryInterceptor
 
enabled() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
enabled(boolean) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Enables or disables the SSL 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.CompatibilityModeConfiguration
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
Sets whether compatibility mode is enabled or disabled.
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.CacheWriterInterceptor
 
enabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns the list of BackupConfiguration that have BackupConfiguration.enabled() == true.
enableFullTextFilter(String) - Method in interface org.infinispan.query.CacheQuery
Enable a given filter by its name.
enableFullTextFilter(String) - Method in class org.infinispan.query.impl.CacheQueryImpl
Enable a given filter by its name.
enableOnRehash() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Entries removed due to a rehash will be moved to L1 rather than being removed altogether.
enableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Enable the background reaper to test entries for expiration.
ENCODE - Static variable in class org.infinispan.commons.util.Base64
Specify encoding.
encodeBytes(byte[]) - Static method in class org.infinispan.commons.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.infinispan.commons.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int) - Static method in class org.infinispan.commons.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.infinispan.commons.util.Base64
Encodes a byte array into Base64 notation.
encodeFromFile(String) - Static method in class org.infinispan.commons.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeObject(Serializable) - Static method in class org.infinispan.commons.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.infinispan.commons.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeToFile(byte[], String) - Static method in class org.infinispan.commons.util.Base64
Convenience method for encoding data to a file.
encodeVersion(int, int, int) - Static method in class org.infinispan.Version
 
Encoding - Class in org.infinispan.cli.commands.server
 
Encoding() - Constructor for class org.infinispan.cli.commands.server.Encoding
 
End - Class in org.infinispan.cli.commands.server
 
End() - Constructor for class org.infinispan.cli.commands.server.End
 
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 class org.infinispan.CacheImpl
 
endBatch(boolean) - Method in interface org.infinispan.commons.api.BatchingCache
Completes a batch if one has been started using BatchingCache.startBatch().
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.
ensureOrder(TotalOrderRemoteTransactionState, Object[]) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
It ensures the validation order for the transaction corresponding to the prepare command.
entitiesLoaded(int) - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
EntityLoader - Class in org.infinispan.query.impl
 
EntityLoader(AdvancedCache<?, ?>, KeyTransformationHandler) - Constructor for class org.infinispan.query.impl.EntityLoader
 
entries - Variable in class org.infinispan.container.DefaultDataContainer
 
entriesMigrated(long, String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
entriesMigrated(long, String, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
entriesMigrated(long, String, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
entriesMigrated(long, String, String) - Method in class org.infinispan.query.logging.Log_$logger
 
entriesMigrated(long, String, String) - Method in interface org.infinispan.util.logging.Log
 
entriesMigrated(long, String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
entriesMigrated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
entriesMigrated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
entriesMigrated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
entriesMigrated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
entriesMigrated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.CacheLoaderInterceptor
 
entryFactory - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
entryFactory - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
entryFactory - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
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
 
entryPurged(K) - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter.PurgeListener
Optional.
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 and cache loader.
entrySet() - Method in class org.infinispan.CacheImpl
 
entrySet() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
entrySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
entrySet() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
EntrySet() - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
 
entrySet - Variable in class org.infinispan.commons.util.AbstractMap
 
entrySet() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
EntrySet() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
entrySet() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
entrySet() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
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() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Set view of the mappings contained in this map.
EntrySetCommand - Class in org.infinispan.commands.read
Command implementation for Map.entrySet() functionality.
EntrySetCommand(DataContainer, InternalEntryFactory, TimeService, Set<Flag>) - 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
 
ENUM_SET_ID - Static variable in interface org.infinispan.marshall.core.Ids
 
EnumerationList<T> - Class in org.infinispan.commons.util
An Enumeration -> List adaptor
EnumerationList(Enumeration<T>) - Constructor for class org.infinispan.commons.util.EnumerationList
Constructor
EnumSetExternalizer - Class in org.infinispan.marshall.exts
EnumSet externalizer.
EnumSetExternalizer() - Constructor for class org.infinispan.marshall.exts.EnumSetExternalizer
 
eq(Object, Object) - Static method in class org.infinispan.commons.util.AbstractMap
 
eq(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is equal to the given value.
equal(Object, Object, Equivalence) - Method in enum org.infinispan.commands.write.ValueMatcher
 
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.client.hotrod.impl.transport.tcp.TcpTransport
 
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.configuration.AbstractTypedPropertiesConfiguration
 
equals(T, Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
 
equals(byte[], Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
equals(T, Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
Indicates whether the objects passed are "equal to" each other.
equals(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
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.commons.io.ByteBufferImpl
 
equals(Object) - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
equals(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Compares the specified object with this map for equality.
equals(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
 
equals(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
equals(Object) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
equals(Object) - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
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.CompatibilityModeConfiguration
 
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.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.LockingConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
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.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.container.versioning.NumericVersion
 
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.lucene.ChunkCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileListCacheKey
 
equals(Object) - Method in class org.infinispan.lucene.FileMetadata
 
equals(Object) - Method in class org.infinispan.lucene.FileReadLockKey
 
equals(Object) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
equals(Object) - Method in class org.infinispan.marshall.core.MarshalledValue
 
equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata
 
equals(Object) - Method in class org.infinispan.metadata.InternalMetadataImpl
 
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.persistence.modifications.ModificationsList
 
equals(Object) - Method in class org.infinispan.persistence.modifications.Remove
 
equals(Object) - Method in class org.infinispan.persistence.modifications.Store
 
equals(Object) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
equals(Object) - Method in class org.infinispan.registry.ScopedKey
 
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.rpc.RpcOptions
 
equals(Object) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
 
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.totalorder.TotalOrderLatchImpl
 
equals(Object) - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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.concurrent.BoundedConcurrentHashMap
 
equals(Object) - Method in class org.infinispan.util.KeyValuePair
 
Equivalence<T> - Interface in org.infinispan.commons.equivalence
An interface that allows custom implementations for objects that are comparable based on equality, hash code calculations, or according to Comparable rules, but where the behaviour provided by the JDK, or external libraries, cannot be modified, for example: arrays.
EquivalentConcurrentHashMapV8<K,V> - Class in org.infinispan.commons.util.concurrent.jdk8backported
A hash table supporting full concurrency of retrievals and high expected concurrency for updates.
EquivalentConcurrentHashMapV8(Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Creates a new, empty map with the default initial table size (16).
EquivalentConcurrentHashMapV8(int, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Creates a new, empty map with an initial table size accommodating the specified number of elements without the need to dynamically resize.
EquivalentConcurrentHashMapV8(Map<? extends K, ? extends V>, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Creates a new map with the same mappings as the given map.
EquivalentConcurrentHashMapV8(int, float, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity) and initial table density (loadFactor).
EquivalentConcurrentHashMapV8(int, float, int, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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).
EquivalentConcurrentHashMapV8.Action<A> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a void action of one argument
EquivalentConcurrentHashMapV8.BiAction<A,B> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a void action of two arguments
EquivalentConcurrentHashMapV8.BiFun<A,B,T> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function of two arguments
EquivalentConcurrentHashMapV8.ConcurrentHashMapSpliterator<T> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
An object for traversing and partitioning elements of a source.
EquivalentConcurrentHashMapV8.DoubleByDoubleToDouble - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping two doubles to a double
EquivalentConcurrentHashMapV8.Fun<A,T> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function of one argument
EquivalentConcurrentHashMapV8.IntByIntToInt - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping two ints to an int
EquivalentConcurrentHashMapV8.KeySetView<K,V> - Class in org.infinispan.commons.util.concurrent.jdk8backported
A view of a EquivalentConcurrentHashMapV8 as a Set of keys, in which additions may optionally be enabled by mapping to a common value.
EquivalentConcurrentHashMapV8.LongByLongToLong - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping two longs to a long
EquivalentConcurrentHashMapV8.ObjectByObjectToDouble<A,B> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping two arguments to a double
EquivalentConcurrentHashMapV8.ObjectByObjectToInt<A,B> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping two arguments to an int
EquivalentConcurrentHashMapV8.ObjectByObjectToLong<A,B> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping two arguments to a long
EquivalentConcurrentHashMapV8.ObjectToDouble<A> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping its argument to a double
EquivalentConcurrentHashMapV8.ObjectToInt<A> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping its argument to an int
EquivalentConcurrentHashMapV8.ObjectToLong<A> - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface describing a function mapping its argument to a long
EquivalentHashMap<K,V> - Class in org.infinispan.commons.equivalence
Custom hash-based map which accepts no null keys nor null values, where equality and hash code calculations are done based on passed Equivalence function implementations for keys and values, as opposed to relying on their own equals/hashCode/toString implementations.
EquivalentHashMap(Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
 
EquivalentHashMap(int, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
 
EquivalentHashMap(int, float, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
 
EquivalentHashMap(Map<? extends K, ? extends V>, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
 
EquivalentHashMap.EntrySet - Class in org.infinispan.commons.equivalence
 
EquivalentHashMap.Node<K,V> - Class in org.infinispan.commons.equivalence
 
EquivalentHashMap.Values - Class in org.infinispan.commons.equivalence
 
EquivalentHashSet<E> - Class in org.infinispan.commons.equivalence
Custom hash-based set which accepts no null values, where equality and hash code calculations are done based on passed Equivalence function implementations for values, as opposed to relying on their own equals/hashCode/toString implementations.
EquivalentHashSet(Equivalence<E>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashSet
Constructs a new, empty set, with a given equivalence function
EquivalentHashSet(int, Equivalence<E>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashSet
Constructs a new, empty set, with a given initial capacity and a particular equivalence function to compare entries.
EquivalentLinkedHashMap<K,V> - Class in org.infinispan.commons.equivalence
Custom hash-based linked list map which accepts no null keys nor null values, where equality and hash code calculations are done based on passed Equivalence function implementations for keys and values, as opposed to relying on their own equals/hashCode/toString implementations.
EquivalentLinkedHashMap(int, float, EquivalentLinkedHashMap.IterationOrder, Equivalence<K>, Equivalence<V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
 
EquivalentLinkedHashMap.IterationOrder - Enum in org.infinispan.commons.equivalence
 
error(String) - Method in interface org.infinispan.cli.Context
 
error(Throwable) - Method in interface org.infinispan.cli.Context
 
error(String) - Method in class org.infinispan.cli.impl.ContextImpl
 
error(Throwable) - Method in class org.infinispan.cli.impl.ContextImpl
 
error(String) - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
error(String) - Method in interface org.infinispan.cli.io.IOAdapter
 
error(String) - Method in class org.infinispan.cli.io.StreamIOAdapter
 
ERROR_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
errorAsyncStoreNotStopped() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorAsyncStoreNotStopped() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorAsyncStoreNotStopped() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorAsyncStoreNotStopped() - Method in class org.infinispan.query.logging.Log_$logger
 
errorAsyncStoreNotStopped() - Method in interface org.infinispan.util.logging.Log
 
errorAsyncStoreNotStopped() - Method in class org.infinispan.util.logging.Log_$logger
 
errorAsyncStoreNotStopped$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorAsyncStoreNotStopped$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorAsyncStoreNotStopped$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorAsyncStoreNotStopped$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorAsyncStoreNotStopped$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in class org.infinispan.query.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in interface org.infinispan.util.logging.Log
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorChangingSingletonStoreStatus$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorChangingSingletonStoreStatus$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorChangingSingletonStoreStatus$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorChangingSingletonStoreStatus$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorChangingSingletonStoreStatus$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorClosingConnectionPool(Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorClosingConnectionPool(Exception) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
errorClosingConnectionPool$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
errorClosingSocket(TcpTransport, IOException) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorClosingSocket(TcpTransport, IOException) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
errorClosingSocket$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in class org.infinispan.query.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in interface org.infinispan.util.logging.Log
 
errorCommittingTx(XAException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCommittingTx$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCommittingTx$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCommittingTx$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCommittingTx$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorCommittingTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String) - Method in class org.infinispan.query.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromConfigFile(String) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigFile$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCreatingChannelFromConfigFile$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingChannelFromConfigFile$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCreatingChannelFromConfigFile$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorCreatingChannelFromConfigFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String) - Method in class org.infinispan.query.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromConfigString(String) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigString$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCreatingChannelFromConfigString$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingChannelFromConfigString$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCreatingChannelFromConfigString$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorCreatingChannelFromConfigString$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromXML(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCreatingChannelFromXML(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingChannelFromXML(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCreatingChannelFromXML(String) - Method in class org.infinispan.query.logging.Log_$logger
 
errorCreatingChannelFromXML(String) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromXML(String) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromXML$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorCreatingChannelFromXML$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingChannelFromXML$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorCreatingChannelFromXML$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorCreatingChannelFromXML$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingTable(String, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
errorCreatingTable(String, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorCreatingTable$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorDoingRemoteCall(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorDoingRemoteCall$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorDoingRemoteCall$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorDoingRemoteCall$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorDoingRemoteCall$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorDoingRemoteCall$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in class org.infinispan.query.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in interface org.infinispan.util.logging.Log
 
errorEnlistingResource(XAException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorEnlistingResource$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorEnlistingResource$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorEnlistingResource$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorEnlistingResource$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorEnlistingResource$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorExecutingParallelStoreTask(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorExecutingParallelStoreTask$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorExecutingParallelStoreTask$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorExecutingParallelStoreTask$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorExecutingParallelStoreTask$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorExecutingParallelStoreTask$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorFlushingToFileChannel(FileChannel, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorFlushingToFileChannel$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorFlushingToFileChannel$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorFlushingToFileChannel$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorFlushingToFileChannel$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorFlushingToFileChannel$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorFromServer(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorFromServer(String) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
errorFromServer$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
errorInstantiatingJdbcDriver(String, Exception) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
errorInstantiatingJdbcDriver(String, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorInstantiatingJdbcDriver$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorMarshallingBucket(IOException, Object) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
errorMarshallingBucket(IOException, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorMarshallingBucket$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorMarshallingObject(IOException, Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorMarshallingObject(IOException, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorMarshallingObject(IOException, Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorMarshallingObject(IOException, Object) - Method in class org.infinispan.query.logging.Log_$logger
 
errorMarshallingObject(IOException, Object) - Method in interface org.infinispan.util.logging.Log
 
errorMarshallingObject(IOException, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
errorMarshallingObject$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorMarshallingObject$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorMarshallingObject$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorMarshallingObject$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorMarshallingObject$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorOnFSDirectoryClose(IOException) - Method in interface org.infinispan.lucene.logging.Log
 
errorOnFSDirectoryClose(IOException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorOnFSDirectoryClose$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessing1pcPrepareCommand(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing1pcPrepareCommand$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessing1pcPrepareCommand$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorProcessing1pcPrepareCommand$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorProcessing1pcPrepareCommand$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorProcessing1pcPrepareCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessing2pcCommitCommand(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing2pcCommitCommand$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessing2pcCommitCommand$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorProcessing2pcCommitCommand$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorProcessing2pcCommitCommand$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorProcessing2pcCommitCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessingPrepare(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingPrepare$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorProcessingPrepare$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorProcessingPrepare$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorProcessingPrepare$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorProcessingPrepare$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingConfiguration(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingConfiguration(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingConfiguration(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingConfiguration(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingConfiguration(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorReadingConfiguration(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingConfiguration$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingConfiguration$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingConfiguration$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingConfiguration$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in interface org.infinispan.util.logging.Log
 
errorReadingFileStore(String, long) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingFileStore$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingFileStore$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingFileStore$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingFileStore$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingFileStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingFromFile(File, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingFromFile(File, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingFromFile(File, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingFromFile(File, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingFromFile(File, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorReadingFromFile(File, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingFromFile$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingFromFile$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingFromFile$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingFromFile$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingFromFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in interface org.infinispan.util.logging.Log
 
errorReadingProperties(IOException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingProperties$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorReadingProperties$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorReadingProperties$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorReadingProperties$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorReadingProperties$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorRollingBack(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorRollingBack$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorRollingBack$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorRollingBack$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorRollingBack$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorRollingBack$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorSuspendingTransaction(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
errorSuspendingTransaction(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorSuspendingTransaction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUnblockingTransactions(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUnblockingTransactions(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorUnblockingTransactions(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorUnblockingTransactions(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorUnblockingTransactions(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorUnblockingTransactions(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorUnblockingTransactions$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUnblockingTransactions$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorUnblockingTransactions$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorUnblockingTransactions$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorUnblockingTransactions$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorUnMarshallingCommand(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUnMarshallingCommand(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorUnMarshallingCommand(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorUnMarshallingCommand(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorUnMarshallingCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorUnMarshallingCommand(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorUnMarshallingCommand$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUnMarshallingCommand$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorUnMarshallingCommand$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorUnMarshallingCommand$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorUnMarshallingCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorUpdatingMembersList(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorUpdatingMembersList$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorUpdatingMembersList$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorUpdatingMembersList$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorUpdatingMembersList$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorUpdatingMembersList$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorWritingValueForAttribute(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorWritingValueForAttribute$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
errorWritingValueForAttribute$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
errorWritingValueForAttribute$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
errorWritingValueForAttribute$str() - Method in class org.infinispan.query.logging.Log_$logger
 
errorWritingValueForAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
escapeBackslashes(String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
Escapes backslashes ('\') with additional backslashes in a given String, returning a new, escaped String.
estimateSize() - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.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 - Class in org.infinispan.cli.commands.server
 
Evict() - Constructor for class org.infinispan.cli.commands.server.Evict
 
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
 
evictionNotAllowedInMetadataCache(String, String) - Method in interface org.infinispan.lucene.logging.Log
 
evictionNotAllowedInMetadataCache(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
evictionNotAllowedInMetadataCache$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
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 class org.infinispan.lucene.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated(Long) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated(Long) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated(Long) - Method in class org.infinispan.query.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated(Long) - Method in interface org.infinispan.util.logging.Log
 
evictionWakeUpIntervalDeprecated(Long) - Method in class org.infinispan.util.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
evictionWakeUpIntervalDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
EXCEPTION_RESPONSE - Static variable in interface org.infinispan.marshall.core.Ids
 
exceptionAndNoRetriesLeft(int, int, HotRodClientException) - Method in interface org.infinispan.client.hotrod.logging.Log
 
exceptionAndNoRetriesLeft(int, int, HotRodClientException) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
exceptionAndNoRetriesLeft$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
exceptionExecutingInboundCommand(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionExecutingInboundCommand(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionExecutingInboundCommand(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionExecutingInboundCommand(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionExecutingInboundCommand(Exception) - Method in interface org.infinispan.util.logging.Log
 
exceptionExecutingInboundCommand(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionExecutingInboundCommand$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionExecutingInboundCommand$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionExecutingInboundCommand$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionExecutingInboundCommand$str() - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionExecutingInboundCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionHandlingCommand$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionHandlingCommand$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionHandlingCommand$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionHandlingCommand$str() - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionHandlingCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionInCacheLoader(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
exceptionInCacheLoader(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionInCacheLoader$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionInvokingListener$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionInvokingListener$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionInvokingListener$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionInvokingListener$str() - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionInvokingListener$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in interface org.infinispan.util.logging.Log
 
exceptionPurgingDataContainer(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionPurgingDataContainer$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
exceptionPurgingDataContainer$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
exceptionPurgingDataContainer$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
exceptionPurgingDataContainer$str() - Method in class org.infinispan.query.logging.Log_$logger
 
exceptionPurgingDataContainer$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
ExcludeTestPackages - Class in org.infinispan.checkstyle.filters
Allows disabling some rules for the test suite source.
ExcludeTestPackages() - Constructor for class org.infinispan.checkstyle.filters.ExcludeTestPackages
 
exec() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Implements execution conventions for CountedCompleters.
exec() - Method in class org.infinispan.commons.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(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.client.Connect
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.client.Container
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.client.Disconnect
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.client.Help
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.client.Quit
 
execute(Context, ProcessedCommand) - Method in interface org.infinispan.cli.commands.Command
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.server.AbstractServerCommand
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.server.Ping
 
execute(Context, ProcessedCommand) - Method in class org.infinispan.cli.commands.server.Version
 
execute(Context, CommandBuffer) - Method in interface org.infinispan.cli.connection.Connection
 
execute(Context, CommandBuffer) - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
execute() - Method in interface org.infinispan.cli.Context
 
execute(CommandBuffer) - Method in interface org.infinispan.cli.Context
 
execute() - Method in class org.infinispan.cli.impl.ContextImpl
 
execute(CommandBuffer) - Method in class org.infinispan.cli.impl.ContextImpl
 
execute() - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
execute() - Method in class org.infinispan.client.hotrod.impl.operations.PingOperation
 
execute() - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
execute(ForkJoinTask<?>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
 
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(BlockingRunnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
execute(Runnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
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(BlockingRunnable) - Method in interface org.infinispan.util.concurrent.BlockingTaskAwareExecutorService
Executes the given command at some time in the future when the command is less probably to block a thread.
execute(BlockingRunnable) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
execute(Runnable) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
execute() - Method in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
Invokes eviction policy algorithm and returns set of evicted entries.
execute(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
executeAsynchronously() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Executes this task across Infinispan cluster nodes asynchronously.
executeAsynchronously(Collator<KOut, VOut, R>) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
Executes this task asynchronously across Infinispan cluster; final result is collated using specified Collator and wrapped by Future
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
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetKeysOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ContainsKeyOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.FaultTolerantPingOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.GetOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.GetWithMetadataOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.GetWithVersionOperation
Deprecated.
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.PutIfAbsentOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.PutOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.QueryOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RemoveIfUnmodifiedOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RemoveOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ReplaceIfUnmodifiedOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.ReplaceOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
executeOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
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 class org.infinispan.lucene.logging.Log_$logger
 
executionError(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
executionError(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
executionError(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
executionError(Throwable) - Method in interface org.infinispan.util.logging.Log
 
executionError(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
executionError$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
executionError$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
executionError$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
executionError$str() - Method in class org.infinispan.query.logging.Log_$logger
 
executionError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
executor - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
Executor service used to submit tasks to push in-memory state.
ExecutorAllCompletionService - Class in org.infinispan.executors
Exectues given tasks in provided executor.
ExecutorAllCompletionService(Executor) - Constructor for class org.infinispan.executors.ExecutorAllCompletionService
 
ExecutorFactory - Interface in org.infinispan.commons.executors
Used to configure and create executors
ExecutorFactoryConfiguration - Class in org.infinispan.client.hotrod.configuration
ExecutorFactoryConfiguration.
ExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
 
ExecutorFactoryConfiguration - Class in org.infinispan.persistence.remote.configuration
 
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
Configures executor factory.
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
Configures executor factory.
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
Configures executor factory.
exhaustedAction() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
exhaustedAction(ExhaustedAction) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Specifies what happens when asking for a connection from a server's pool, and that pool is exhausted.
ExhaustedAction - Enum in org.infinispan.client.hotrod.configuration
Enumeration for whenExhaustedAction.
exhaustedAction() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
exhaustedAction(ExhaustedAction) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Specifies what happens when asking for a connection from a server's pool, and that pool is exhausted.
ExhaustedAction - Enum in org.infinispan.persistence.remote.configuration
 
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.
expectedEndTime(long, TimeUnit) - Method in class org.infinispan.util.DefaultTimeService
 
expectedEndTime(long, TimeUnit) - Method in interface org.infinispan.util.TimeService
 
expectedJustOneResponse(Map) - Method in class org.infinispan.lucene.logging.Log_$logger
 
expectedJustOneResponse(Map) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
expectedJustOneResponse(Map) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
expectedJustOneResponse(Map) - Method in class org.infinispan.query.logging.Log_$logger
 
expectedJustOneResponse(Map<Address, Response>) - Method in interface org.infinispan.util.logging.Log
 
expectedJustOneResponse(Map) - Method in class org.infinispan.util.logging.Log_$logger
 
expectedJustOneResponse$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
expectedJustOneResponse$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
expectedJustOneResponse$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
expectedJustOneResponse$str() - Method in class org.infinispan.query.logging.Log_$logger
 
expectedJustOneResponse$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
ExpiredFilteredKeySet(Set<Object>, DataContainer) - Constructor for class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
ExpiredFilteredValues(Set<InternalCacheEntry>, TimeService) - Constructor for class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
ExpiryHelper - Class in org.infinispan.container.entries
Provide utility methods for dealing with expiration of cache entries.
ExpiryHelper() - Constructor for class org.infinispan.container.entries.ExpiryHelper
 
expiryTime() - Method in interface org.infinispan.metadata.InternalMetadata
 
expiryTime() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
explain(int) - Method in interface org.infinispan.query.CacheQuery
Return the Lucene Explanation object describing the score computation for the matching object/document in the current query
explain(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
ExposedByteArrayOutputStream - Class in org.infinispan.commons.io
Extends ByteArrayOutputStream, but exposes the internal buffer.
ExposedByteArrayOutputStream() - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
ExposedByteArrayOutputStream - Class in org.infinispan.io
Deprecated.
ExposedByteArrayOutputStream() - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
 
ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
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.core.Ids
 
ExtendedModuleCommandFactory - Interface in org.infinispan.commands.module
Temporary workaround to avoid modifying ModuleCommandFactory interface.
ExtendedRiverMarshaller - Class in org.infinispan.commons.marshall.jboss
RiverMarshaller extension that allows Infinispan code to directly create instances of it.
ExtendedRiverMarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.commons.marshall.jboss.ExtendedRiverMarshaller
 
ExtendedRiverUnmarshaller - Class in org.infinispan.commons.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 org.infinispan.commons.marshall.MarshalledValue.Externalizer
ExtendedRiverUnmarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.commons.marshall.jboss.ExtendedRiverUnmarshaller
 
Externalizer() - Constructor for class org.infinispan.atomic.AtomicHashMap.Externalizer
 
Externalizer() - Constructor for class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
Externalizer() - Constructor for class org.infinispan.atomic.ClearOperation.Externalizer
 
Externalizer() - Constructor for class org.infinispan.atomic.PutOperation.Externalizer
 
Externalizer() - Constructor for class org.infinispan.atomic.RemoveOperation.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash2.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash2Compat.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.io.ByteBufferImpl.Externalizer
 
Externalizer<T> - Interface in org.infinispan.commons.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.
Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.versioning.NumericVersion.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersion.Externalizer
 
Externalizer() - Constructor for class org.infinispan.context.Flag.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.SyncConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.TopologyAwareConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.TopologyAwareSyncConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
Externalizer() - Constructor for class org.infinispan.lucene.FileCacheKey.Externalizer
 
Externalizer() - Constructor for class org.infinispan.lucene.FileListCacheKey.Externalizer
 
Externalizer() - Constructor for class org.infinispan.lucene.FileMetadata.Externalizer
 
Externalizer() - Constructor for class org.infinispan.lucene.FileReadLockKey.Externalizer
 
Externalizer(StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
Externalizer(StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledValue.Externalizer
 
Externalizer<T> - Interface in org.infinispan.marshall
Deprecated.
Use Externalizer instead
Externalizer() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
Externalizer() - Constructor for class org.infinispan.metadata.InternalMetadataImpl.Externalizer
 
Externalizer() - Constructor for class org.infinispan.registry.ScopedKey.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
Externalizer() - Constructor for class org.infinispan.statetransfer.StateChunk.Externalizer
 
Externalizer() - Constructor for class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.CacheJoinInfo.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.CacheTopology.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.util.KeyValuePair.Externalizer
 
ExternalizerIds - Interface in org.infinispan.lucene
Identifiers used by the Marshaller to delegate to specialized Externalizers.
ExternalizerTable - Class in org.infinispan.marshall.core
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.core.ExternalizerTable
 
ExternalStore<K,V> - Interface in org.infinispan.persistence.spi
Basic interface for interacting with an external store in a read-write mode.
extractFieldName(String) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
extractKey(DocumentExtractor, Cache<?, ?>, KeyTransformationHandler, int) - Static method in class org.infinispan.query.clustered.commandworkers.QueryExtractorUtil
 
extractProperties(Element) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
extractValue(MVCCEntry) - Method in enum org.infinispan.commands.write.ValueMatcher
 

F

factory() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
 
factory(ExecutorFactory) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Specify factory class for executor
factory - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
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() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfiguration
 
factory(ExecutorFactory) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Specify factory class for executor NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
factoryClass() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
 
factoryClass(Class<? extends ExecutorFactory>) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Specify factory class for executor
factoryClass(String) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
failAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
failedAddingNewServer(SocketAddress, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
failedAddingNewServer(SocketAddress, Exception) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
failedAddingNewServer$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
failedClearingJdbcCacheStore(Exception) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
failedClearingJdbcCacheStore(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedClearingJdbcCacheStore$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedClosingNamingCtx(NamingException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
failedClosingNamingCtx(NamingException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedClosingNamingCtx$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedInvalidatingRemoteCache(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedInvalidatingRemoteCache(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedInvalidatingRemoteCache(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedInvalidatingRemoteCache(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
failedInvalidatingRemoteCache(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedInvalidatingRemoteCache(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedInvalidatingRemoteCache$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedInvalidatingRemoteCache$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedInvalidatingRemoteCache$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedInvalidatingRemoteCache$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedInvalidatingRemoteCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingKeysFromCacheStore(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingKeysFromCacheStore$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedLoadingKeysFromCacheStore$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedLoadingKeysFromCacheStore$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedLoadingKeysFromCacheStore$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedLoadingKeysFromCacheStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingValueFromCacheStore$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedLoadingValueFromCacheStore$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedLoadingValueFromCacheStore$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedLoadingValueFromCacheStore$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedLoadingValueFromCacheStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedOutBoundTransferExecution(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedOutBoundTransferExecution$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedOutBoundTransferExecution$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedOutBoundTransferExecution$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedOutBoundTransferExecution$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedOutBoundTransferExecution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedReplicatingQueue(int, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedReplicatingQueue(int, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedReplicatingQueue(int, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedReplicatingQueue(int, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedReplicatingQueue(int, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedReplicatingQueue(int, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedReplicatingQueue$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedReplicatingQueue$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedReplicatingQueue$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedReplicatingQueue$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedReplicatingQueue$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedSynchronizationRegistration(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedSynchronizationRegistration$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedSynchronizationRegistration$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedSynchronizationRegistration$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedSynchronizationRegistration$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedSynchronizationRegistration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToCallStopAfterFailure(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCallStopAfterFailure$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCallStopAfterFailure$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToCallStopAfterFailure$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToCallStopAfterFailure$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToCallStopAfterFailure$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCloseResource(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCloseResource(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToCloseResource(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToCloseResource(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToCloseResource(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToCloseResource(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCloseResource$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCloseResource$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToCloseResource$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToCloseResource$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToCloseResource$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in interface org.infinispan.util.logging.Log
 
failedToCreateInitialCtx(NamingException) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCreateInitialCtx$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCreateInitialCtx$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToCreateInitialCtx$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToCreateInitialCtx$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToCreateInitialCtx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCreateLucene4Directory(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
failedToCreateLucene4Directory(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToCreateLucene4Directory$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToInvalidateKeys(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToInvalidateKeys$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToInvalidateKeys$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToInvalidateKeys$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToInvalidateKeys$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToInvalidateKeys$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRecoverCacheState(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverCacheState$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRecoverCacheState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRecoverCacheState$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRecoverCacheState$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRecoverCacheState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRecoverClusterState(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverClusterState$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRecoverClusterState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRecoverClusterState$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRecoverClusterState$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRecoverClusterState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRequestSegments(Collection, String, Address, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRequestSegments(Collection, String, Address, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRequestSegments(Collection, String, Address, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRequestSegments(Collection, String, Address, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRequestSegments(Collection<Integer>, String, Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRequestSegments(Collection, String, Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRequestSegments$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRequestSegments$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRequestSegments$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRequestSegments$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRequestSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(Collection, String, Address, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(Collection, String, Address, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(Collection, String, Address, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(Collection, String, Address, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(Collection<Integer>, String, Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToRetrieveTransactionsForSegments(Collection, String, Address, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in class org.infinispan.query.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
failedToUpdateAttribute(String, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToUpdateAttribute$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
failedToUpdateAttribute$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failedToUpdateAttribute$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
failedToUpdateAttribute$str() - Method in class org.infinispan.query.logging.Log_$logger
 
failedToUpdateAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
failureClosingConnection(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
failureClosingConnection(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
failureClosingConnection$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
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 class org.infinispan.lucene.logging.Log_$logger
 
fallingBackToDummyTm() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
fallingBackToDummyTm() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
fallingBackToDummyTm() - Method in class org.infinispan.query.logging.Log_$logger
 
fallingBackToDummyTm() - Method in interface org.infinispan.util.logging.Log
 
fallingBackToDummyTm() - Method in class org.infinispan.util.logging.Log_$logger
 
fallingBackToDummyTm$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
fallingBackToDummyTm$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
fallingBackToDummyTm$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
fallingBackToDummyTm$str() - Method in class org.infinispan.query.logging.Log_$logger
 
fallingBackToDummyTm$str() - Method in class org.infinispan.util.logging.Log_$logger
 
FastCopyHashMap<K,V> - Class in org.infinispan.commons.util
A HashMap that is optimized for fast shallow copies.
FastCopyHashMap(int, float) - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap(int) - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap() - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap.EntrySet - Class in org.infinispan.commons.util
 
FastCopyHashMap.KeySet - Class in org.infinispan.commons.util
 
FastCopyHashMap.Values - Class in org.infinispan.commons.util
 
FaultTolerantPingOperation - Class in org.infinispan.client.hotrod.impl.operations
A fault tolerant ping operation that can survive to node failures.
FaultTolerantPingOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.FaultTolerantPingOperation
 
fclose(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Attempt to flush and close an OutputStream.
fclose(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to flush and close an array of OutputStreams.
fetchExecutionContext(CommandInitializer) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
fetchExecutionContext(CommandInitializer) - Method in interface org.infinispan.query.impl.CustomQueryCommand
 
fetchExecutionContext(CommandInitializer) - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
This is invoked only on the receiving node, before IndexUpdateCommand.perform(InvocationContext)
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.
fetchMode(FetchOptions.FetchMode) - Method in class org.infinispan.query.FetchOptions
Set the fetch mode to be used to fetch matching results
FetchOptions - Class in org.infinispan.query
 
FetchOptions() - Constructor for class org.infinispan.query.FetchOptions
 
FetchOptions.FetchMode - Enum in org.infinispan.query
Specifies the fetching strategy for query results.
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 class org.infinispan.configuration.cache.PersistenceConfiguration
Loops through all individual cache loader configs and checks if fetchPersistentState is set on any of them
fetchPersistentState() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
If true, fetch persistent state when joining a cluster.
fetchPersistentState(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
If true, fetch persistent state when joining a cluster.
fetchSize() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
fetchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
For DB queries the fetch size will be set on ResultSet.setFetchSize(int).
fetchSize() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
fetchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
For DB queries the fetch size is on ResultSet.setFetchSize(int).
fetchSize(int) - Method in class org.infinispan.query.FetchOptions
Set the fetch size for batch loading of matches
fetchValue(ClusteredDoc, ClusteredTopDocs) - Method in class org.infinispan.query.clustered.DistributedIterator
 
fetchValue(ClusteredDoc, ClusteredTopDocs) - Method in class org.infinispan.query.clustered.DistributedLazyIterator
 
fieldNotFound(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
fieldNotFound(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
fieldNotFound(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
fieldNotFound(String) - Method in class org.infinispan.query.logging.Log_$logger
 
fieldNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
fieldNotFound(String) - Method in class org.infinispan.util.logging.Log_$logger
 
fieldNotFound$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
fieldNotFound$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
fieldNotFound$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
fieldNotFound$str() - Method in class org.infinispan.query.logging.Log_$logger
 
fieldNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
fifoOrder() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
fifoOrder(boolean) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Note: this option may be set to false if by the current Transport if the ResponseMode.isSynchronous() returns true.
FILE - Static variable in class org.infinispan.io.GridFile.Metadata
 
FILE_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FILE_LIST_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FILE_METADATA - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FILE_READLOCK_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
FileCacheKey - Class in org.infinispan.lucene
Used as a key for file headers in a cache
FileCacheKey(String, String) - Constructor for class org.infinispan.lucene.FileCacheKey
 
FileCacheKey.Externalizer - Class in org.infinispan.lucene
 
fileExists(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
fileExists(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
fileExists(String) - Method in interface org.infinispan.lucene.cacheloader.InternalDirectoryContract
 
fileExists(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
fileLength(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
fileLength(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
fileLength(String) - Method in interface org.infinispan.lucene.cacheloader.InternalDirectoryContract
 
fileLength(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
FileListCacheKey - Class in org.infinispan.lucene
Cache key for a list with current files in cache
FileListCacheKey(String) - Constructor for class org.infinispan.lucene.FileListCacheKey
 
FileListCacheKey.Externalizer - Class in org.infinispan.lucene
 
FileListOperations - Class in org.infinispan.lucene.impl
Collects operations on the existing fileList, stored as a Set having key of type FileListCacheKey(indexName).
FileListOperations(AdvancedCache<?, ?>, String) - Constructor for class org.infinispan.lucene.impl.FileListOperations
 
FileLookup - Interface in org.infinispan.commons.util
Holds the logic of looking up a file, in the following sequence:
FileLookup - Class in org.infinispan.util
Deprecated.
Use the new org.infinispan.commons.util.FileLookup
FileLookupFactory - Class in org.infinispan.commons.util
 
FileLookupFactory() - Constructor for class org.infinispan.commons.util.FileLookupFactory
 
FileLookupFactory - Class in org.infinispan.util
Deprecated.
Use the new org.infinispan.commons.util.FileLookupFactory
FileLookupFactory.DefaultFileLookup - Class in org.infinispan.commons.util
 
FileMetadata - Class in org.infinispan.lucene
Header for Lucene files.
FileMetadata(int) - Constructor for class org.infinispan.lucene.FileMetadata
 
FileMetadata.Externalizer - Class in org.infinispan.lucene
 
fileModified(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
fileModified(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
fileModified(String) - Method in interface org.infinispan.lucene.cacheloader.InternalDirectoryContract
 
fileModified(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
filename(String) - Static method in class org.infinispan.io.GridFile
 
FileReadLockKey - Class in org.infinispan.lucene
Lucene's index segment files are chunked, for safe deletion of elements a read lock is implemented so that all chunks are deleted only after the usage counter is decremented to zero.
FileReadLockKey(String, String) - Constructor for class org.infinispan.lucene.FileReadLockKey
 
FileReadLockKey.Externalizer - Class in org.infinispan.lucene
 
fillInStackTrace() - Method in exception org.infinispan.commons.marshall.NotSerializableException
 
filter - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
filter(Filter) - Method in interface org.infinispan.query.CacheQuery
Allows lucene to filter the results.
filter(Filter) - Method in class org.infinispan.query.impl.CacheQueryImpl
Takes in a lucene filter and sets it to the filter field in the class.
filterCondition - Variable in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
FilterConditionBeginContext - Interface in org.infinispan.query.dsl
The beginning context of an incomplete condition.
FilterConditionContext - Interface in org.infinispan.query.dsl
The context of a complete filter.
FilterConditionEndContext - Interface in org.infinispan.query.dsl
The context that ends a condition.
FilteringListenable - Interface in org.infinispan.notifications
A Listable that can also filter events based on key
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.commons.util.ReflectionUtil
 
findMethod(Class<?>, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
findMethod(Class<?>, String, Class<?>[]) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
findNewBackupOwner(DefaultConsistentHashFactory.Builder, Collection<Address>, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
findNewPrimaryOwner(DefaultConsistentHashFactory.Builder, Collection<Address>, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
findNextHighestPowerOfTwo(int) - Static method in class org.infinispan.commons.util.Util
Returns a number such that the number is a power of two that is equal to, or greater than, the number passed in as an argument.
findSetterForField(Class<?>, String) - Static method in class org.infinispan.commons.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.commons.marshall.jboss.ExtendedRiverMarshaller
 
finish() - Method in class org.infinispan.commons.marshall.jboss.ExtendedRiverUnmarshaller
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
finishObjectInput(ObjectInput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Finish using the given ObjectInput.
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
finishObjectInput(ObjectInput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Finish using the given ObjectInput.
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Finish using the given ObjectOutput.
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Finish using the given ObjectOutput.
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
fireParsingComplete() - Method in class org.infinispan.configuration.parsing.AbstractParserContext
 
fireParsingComplete() - Method in interface org.infinispan.configuration.parsing.ParserContext
 
first() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
firstComplete() - Method in class org.infinispan.commons.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
 
firstResult(int) - Method in interface org.infinispan.query.CacheQuery
Sets a result with a given index to the first result.
firstResult(int) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
firstResult(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
Sets the the result of the given integer value to the first result.
Flag - Enum in org.infinispan.client.hotrod
Defines all the flags available in the Hot Rod client that can influence the behavior of operations.
Flag - Enum in org.infinispan.context
Available flags, which may be set on a per-invocation basis.
FLAG - Static variable in interface org.infinispan.marshall.core.Ids
 
Flag.Externalizer - Class in org.infinispan.context
 
FlagAffectedCommand - Interface in org.infinispan.commands
Commands affected by Flags should carry them over to the remote nodes.
flags - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
flags(Flag[]) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
flags - Variable in class org.infinispan.commands.AbstractLocalFlagAffectedCommand
 
flags - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
FLOAT - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
floatValue() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
fluentSetterName(String) - Static method in class org.infinispan.commons.util.BeanUtils
Retrieves a setter name based on a field name passed in
flush() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
flush() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
flush() - Method in class org.infinispan.io.GridOutputStream
 
flush() - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
flush() - Method in class org.infinispan.io.WritableGridFileChannel
 
flush() - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
flush() - Method in class org.infinispan.query.impl.massindex.IndexingReducer
Since indexing work is done asynchronously in the backend, we need to flush at the end to make sure we don't return control to user before all work was processed and flushed.
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.commons.util.Util
 
flushAndCloseStream(OutputStream) - Static method in class org.infinispan.commons.util.Util
 
flushBase64() - Method in class org.infinispan.commons.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
 
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.
FORCE_RETURN_VALUES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
forceCommit(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceCommit(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceLoad(Object, Set<Flag>) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
forceLoad(Object, Set<Flag>) - Method in class org.infinispan.interceptors.ClusteredActivationInterceptor
 
forceLoad(Object, Set<Flag>) - Method in class org.infinispan.interceptors.ClusteredCacheLoaderInterceptor
 
forceOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
forceReturnValues(boolean) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
forceReturnValues() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
forceReturnValues(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
forceReturnValues(boolean) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Whether or not to implicitly FORCE_RETURN_VALUE for all calls.
forceReturnValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
forceReturnValues() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
forceReturnValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
forceReturnValues(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Whether or not to implicitly FORCE_RETURN_VALUE for all calls.
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(EquivalentConcurrentHashMapV8.BiAction<? super K, ? super V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
 
forEach(long, EquivalentConcurrentHashMapV8.BiAction<? super K, ? super V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each (key, value).
forEach(long, EquivalentConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>, EquivalentConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each non-null transformation of each (key, value).
forEach(EquivalentConcurrentHashMapV8.Action<? super K>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
 
forEachEntry(long, EquivalentConcurrentHashMapV8.Action<? super Map.Entry<K, V>>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each entry.
forEachEntry(long, EquivalentConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>, EquivalentConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each non-null transformation of each entry.
forEachKey(long, EquivalentConcurrentHashMapV8.Action<? super K>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each key.
forEachKey(long, EquivalentConcurrentHashMapV8.Fun<? super K, ? extends U>, EquivalentConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each non-null transformation of each key.
forEachRemaining(EquivalentConcurrentHashMapV8.Action<? super T>) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ConcurrentHashMapSpliterator
Applies the action to each untraversed element
forEachValue(long, EquivalentConcurrentHashMapV8.Action<? super V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each value.
forEachValue(long, EquivalentConcurrentHashMapV8.Fun<? super V, ? extends U>, EquivalentConcurrentHashMapV8.Action<? super U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Performs the given action for each non-null transformation of each value.
foreignExternalizerUsingNegativeId(AdvancedExternalizer, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
foreignExternalizerUsingNegativeId(AdvancedExternalizer, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
foreignExternalizerUsingNegativeId(AdvancedExternalizer, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
foreignExternalizerUsingNegativeId(AdvancedExternalizer, int) - Method in class org.infinispan.query.logging.Log_$logger
 
foreignExternalizerUsingNegativeId(AdvancedExternalizer<?>, int) - Method in interface org.infinispan.util.logging.Log
 
foreignExternalizerUsingNegativeId(AdvancedExternalizer, int) - Method in class org.infinispan.util.logging.Log_$logger
 
foreignExternalizerUsingNegativeId$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
foreignExternalizerUsingNegativeId$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
foreignExternalizerUsingNegativeId$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
foreignExternalizerUsingNegativeId$str() - Method in class org.infinispan.query.logging.Log_$logger
 
foreignExternalizerUsingNegativeId$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.commons.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.commons.util.concurrent.jdk8backported
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class org.infinispan.commons.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.commons.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.commons.util.concurrent.jdk8backported.ForkJoinPool
Creates a ForkJoinPool with the given parameters.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in org.infinispan.commons.util.concurrent.jdk8backported
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinTask<V> - Class in org.infinispan.commons.util.concurrent.jdk8backported
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
 
ForkJoinWorkerThread - Class in org.infinispan.commons.util.concurrent.jdk8backported
A thread managed by a ForkJoinPool, which executes ForkJoinTasks.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.
format(Configuration) - Method in class org.infinispan.configuration.format.PropertyFormatter
 
format(GlobalConfiguration) - Method in class org.infinispan.configuration.format.PropertyFormatter
 
formatString(Object, Object...) - Static method in class org.infinispan.commons.util.Util
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Element
 
forName(String) - Static method in enum org.infinispan.persistence.cli.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.persistence.cli.configuration.Element
 
forName(String) - Static method in enum org.infinispan.persistence.jdbc.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.persistence.jdbc.configuration.Element
 
forName(String) - Static method in enum org.infinispan.persistence.remote.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.persistence.remote.configuration.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.commons.util
A list which forwards all its method calls to another list.
ForwardingList() - Constructor for class org.infinispan.commons.util.ForwardingList
Constructor for use by subclasses.
friendlyCacheModeString() - Method in enum org.infinispan.configuration.cache.CacheMode
 
from(Class) - Method in class org.infinispan.client.hotrod.impl.query.RemoteQueryFactory
 
from(Class) - Method in class org.infinispan.query.dsl.embedded.impl.EmbeddedLuceneQueryFactory
 
from(Class) - Method in interface org.infinispan.query.dsl.QueryFactory
Creates a QueryBuilder for the given entity type.
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(byte, Object[], byte, String) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
fromStream(byte, Object[]) - Method in class org.infinispan.query.impl.CommandFactory
 
fromStream(byte, Object[], String) - Method in class org.infinispan.query.impl.CommandFactory
 
fromString(String) - Method in class org.infinispan.query.impl.DefaultTransformer
 
fromString(String) - Method in interface org.infinispan.query.Transformer
 
futureDone(Future<T>) - Method in interface org.infinispan.commons.util.concurrent.FutureListener
 
futureDone(Future<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService.QueueingListener
 
FutureListener<T> - Interface in org.infinispan.commons.util.concurrent
A listener that is called back when a future is done.
FutureListener<T> - Interface in org.infinispan.util.concurrent
Deprecated.
Use FutureListener instead

G

generateNew() - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
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
 
generateStatistics - Variable in class org.infinispan.interceptors.CacheWriterInterceptor.Updater
 
GenericJBossMarshaller - Class in org.infinispan.commons.marshall.jboss
A marshaller that makes use of JBoss Marshalling to serialize and deserialize objects.
GenericJBossMarshaller() - Constructor for class org.infinispan.commons.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 - Class in org.infinispan.cli.commands.server
 
Get() - Constructor for class org.infinispan.cli.commands.server.Get
 
get() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
get(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
get(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
get(Object) - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
 
get() - Method in class org.infinispan.commons.util.ByRef
 
get(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.AbstractInProcessFuture
 
get() - Method in class org.infinispan.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
get(Object) - Method in class org.infinispan.commons.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.commons.util.concurrent.DeferredReturnFuture
 
get(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
get(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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.commons.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.commons.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.commons.util.concurrent.NoOpFuture
 
get(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
get() - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
get(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
get() - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
get(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
get(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
get(int) - Method in class org.infinispan.commons.util.ForwardingList
 
get(int) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
get(int) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList
 
get(Object) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
get(Object) - Method in class org.infinispan.commons.util.WeakValueHashMap
 
get() - Method in interface org.infinispan.commons.util.WeakValueHashMap.ValueRef
Get underlying value.
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.interceptors.distribution.L1WriteSynchronizer
 
get(long, TimeUnit) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
get() - Method in class org.infinispan.marshall.core.MarshalledValue
Returns the 'cached' instance
get(S, K) - Method in interface org.infinispan.registry.ClusterRegistry
 
get(S, K) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
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_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_METADATA - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_METADATA_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_VERSION - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
GET_WITH_VERSION_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
getAbsoluteFile() - Method in class org.infinispan.io.GridFile
 
getAbsolutePath() - Method in class org.infinispan.io.GridFile
 
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
 
getActiveCache() - Method in interface org.infinispan.cli.connection.Connection
 
getActiveCache() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
getActiveContainer() - Method in interface org.infinispan.cli.connection.Connection
 
getActiveContainer() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
getActiveThreadCount() - Method in class org.infinispan.commons.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 class org.infinispan.query.clustered.QueryResponse
 
getAddress() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the address associated with this RpcManager or null if not part of the cluster.
getAddress() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAddress() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
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
 
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
 
getAffectedKeysToLock(boolean) - Method in class org.infinispan.commands.tx.PrepareCommand
It returns an array of keys affected by the WriteCommand in modifications.
getAllLoaders() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getAllMachinesCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllMethods(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllMethodsShallow(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.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
 
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
 
getAllWriters() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getAnnotatedFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
getAnnotation(Class<?>, Class<T>) - Static method in class org.infinispan.commons.util.ReflectionUtil
Inspects the class passed in for the class level annotation specified.
getAppConfigFolder(String) - Static method in class org.infinispan.cli.util.SystemUtils
Returns an appropriate system-dependent folder for storing application-specific data.
getArgument(int) - Method in class org.infinispan.cli.commands.ProcessedCommand
 
getArguments() - Method in class org.infinispan.cli.commands.ProcessedCommand
 
getAsInputStreamFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
getAsInputStreamFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
getAsURLFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
getAsURLFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.OsgiFileLookup
 
getAsync(K) - Method in class org.infinispan.AbstractDelegatingCache
 
getAsync(K) - Method in interface org.infinispan.api.BasicCache
Deprecated.
Asynchronous version of Map.get(Object) that allows user code to retrieve the value associated with a key at a later stage, hence allowing multiple parallel get requests to be sent.
getAsync(K) - Method in class org.infinispan.CacheImpl
 
getAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getAsync(K) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #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.DecoratedCache
 
getAsyncExecutor() - Method in class org.infinispan.query.backend.QueryInterceptor
Use this executor for Async operations
getAsyncExecutorFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAsyncMode() - Method in class org.infinispan.commons.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
 
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.
getAttribute(String) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributeMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getAttributePath() - Method in class org.infinispan.query.dsl.impl.SortCriteria
 
getAttributePath() - Method in class org.infinispan.query.remote.client.QueryRequest.SortCriteria
 
getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributeValue(Element, String, String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
Retrieves the value of a given attribute for the first encountered instance of a tag in an element.
getAvailableCaches() - Method in interface org.infinispan.cli.connection.Connection
 
getAvailableCaches() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
getAvailableContainers() - Method in interface org.infinispan.cli.connection.Connection
 
getAvailableContainers() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
getAverageReadTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAverageReadTime() - Method in interface org.infinispan.stats.Stats
 
getAverageReadTime() - Method in class org.infinispan.stats.StatsImpl
 
getAverageRemoveTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAverageRemoveTime() - Method in interface org.infinispan.stats.Stats
 
getAverageRemoveTime() - Method in class org.infinispan.stats.StatsImpl
 
getAverageReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAverageWriteTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getAverageWriteTime() - Method in interface org.infinispan.stats.Stats
 
getAverageWriteTime() - Method in class org.infinispan.stats.StatsImpl
 
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
 
getBalancer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
Note that the returned RequestBalancingStrategy may not be thread-safe.
getBatchContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getBatchContainer() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of batching cache operations.
getBatchContainer() - Method in class org.infinispan.CacheImpl
 
getBatchSize() - Method in class org.infinispan.persistence.jdbc.TableManipulation
When doing repetitive DB inserts this will be batched according to this parameter.
getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
 
getBinaryStore() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getBooleanProperty(String, boolean, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getBooleanProperty(String, boolean, boolean) - Method in class org.infinispan.commons.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
 
getBuckedId(Object) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
getBucketId() - Method in class org.infinispan.persistence.support.Bucket
 
getBucketIdAsString() - Method in class org.infinispan.persistence.support.Bucket
 
getBuf() - Method in interface org.infinispan.commons.io.ByteBuffer
Returns the underlying buffer.
getBuf() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getBufferedCommands() - Method in interface org.infinispan.cli.CommandBuffer
 
getBufferedCommands() - Method in class org.infinispan.cli.impl.CommandBufferImpl
 
getBufferSize() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the bufferSize.
getBufferSize() - Method in class org.infinispan.lucene.FileMetadata
 
getBufferSizePredictor(Object) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
getBufferSizePredictor(Object) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
 
getBufferSizePredictor(Class<?>) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
Get the serialized form size predictor for a particular type.
getBufferSizePredictor(Object) - Method in interface org.infinispan.commons.marshall.Marshaller
Returns a marshalled payload size predictor for a particular type.
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
getBufferSizePredictor(Object) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
Returns a marshalled payload size predictor for a particular type.
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
getBufferSizePredictor(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
getBulk() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getBulk(int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getBulk() - Method in interface org.infinispan.client.hotrod.RemoteCache
Bulk get operations, returns all the entries within the remote cache.
getBulk(int) - Method in interface org.infinispan.client.hotrod.RemoteCache
Same as RemoteCache.getBulk(), but limits the returned set of values to the specified size.
getByteBufferFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getByteBufferFactory() - Method in class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
getByteBufferFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
To be used for building ByteBuffer objects.
getCache() - Method in interface org.infinispan.api.BasicCacheContainer
Deprecated.
Retrieves the default cache associated with this cache container.
getCache(String) - Method in interface org.infinispan.api.BasicCacheContainer
Deprecated.
Retrieves a named cache from the system.
getCache() - Method in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
getCache() - Method in interface org.infinispan.cli.connection.jmx.JMXUrl
 
getCache() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getCache(String) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves a named cache from the remote server if the cache has been defined, otherwise if the cache name is underfined, it will return null.
getCache(String, boolean) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves the default cache from the remote server.
getCache(boolean) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache() - Method in interface org.infinispan.commons.api.BasicCacheContainer
Retrieves the default cache associated with this cache container.
getCache(String) - Method in interface org.infinispan.commons.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 class org.infinispan.persistence.InitializationContextImpl
 
getCache() - Method in class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
getCache() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
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(K) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getCacheEntry(K) - 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(K) - Method in class org.infinispan.CacheImpl
 
getCacheEntry() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
getCacheEntry(K) - Method in class org.infinispan.DecoratedCache
 
getCacheLoaderLoads() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getCacheLoaderMisses() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
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
 
getCacheManager() - Method in class org.infinispan.query.impl.CommandInitializer
 
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
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);
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.core.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.
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
 
getCacheTopology(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
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
 
getCapacityFactor(Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getCapacityFactor(Address) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getCapacityFactor() - Method in class org.infinispan.topology.CacheJoinInfo
 
getCapacityFactors() - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getCapacityFactors() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
getCapacityFactors() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getChangeLogSize() - Method in class org.infinispan.atomic.AtomicHashMapDelta
 
getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getChunkId() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the chunkId.
getChunkSize() - Method in class org.infinispan.io.GridFile
Guaranteed to be a power of two
getChunkSize() - Method in class org.infinispan.io.GridFile.Metadata
 
getClassForName(String, ClassLoader) - Static method in class org.infinispan.commons.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.commons.marshall.jboss.DefaultContextClassResolver
 
getClassLoader(Configuration, GlobalConfiguration) - Static method in class org.infinispan.configuration.cache.Configurations
 
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.factories.AbstractComponentRegistry
 
getClassLoader() - Method in class org.infinispan.factories.ComponentRegistry
 
getClassLoader() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getClassLoader() - Method in class org.infinispan.marshall.core.JBossMarshaller.EmbeddedContextClassResolver
 
getClassLoaders(ClassLoader) - Static method in class org.infinispan.commons.util.Util
 
getClassMapping(String) - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getClassMappings() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getClazz() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getClusteredQuery(Query, Class<?>...) - Method in class org.infinispan.query.impl.SearchManagerImpl
This probably should be hided in the getQuery method.
getClusteredQuery(Query, Class<?>...) - Method in interface org.infinispan.query.SearchManager
Experimental! Use it to try out the newly introduced distributed queries.
getClusterMembers() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterName() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getClusterName() - Method in class org.infinispan.manager.DefaultCacheManager
getClusterName() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClusterSize() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCode() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getCodec(String) - Static method in class org.infinispan.client.hotrod.impl.protocol.CodecFactory
 
getCoinToss() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
getCollocatedKey(K) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the same node as the supplied key.
getCollocatedKey(K) - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getCombiner() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getCommand(String) - Method in class org.infinispan.cli.CommandRegistry
 
getCommand() - Method in class org.infinispan.cli.commands.ProcessedCommand
 
getCommand() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommand(Cache<?, ?>, HSQuery, UUID, int) - Method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
 
getCommandAwareRpcDispatcher() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCommandBuffer() - Method in interface org.infinispan.cli.Context
 
getCommandBuffer() - Method in class org.infinispan.cli.impl.ContextImpl
 
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.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.totalorder.TotalOrderCommitCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderRollbackCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedCommitCommand
 
getCommandId() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
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.query.clustered.ClusteredQueryCommand
 
getCommandId() - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
getCommandLine() - Method in class org.infinispan.cli.commands.ProcessedCommand
 
getCommandNames() - Method in class org.infinispan.cli.CommandRegistry
 
getCommandRegistry() - Method in interface org.infinispan.cli.Context
 
getCommandRegistry() - Method in class org.infinispan.cli.impl.ContextImpl
 
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.commons.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.commons.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
 
getComponent(Cache<?, ?>, Class<T>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getComponent(Cache<?, ?>, Class<T>, String) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
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.util.concurrent.locks.LockManagerImpl
 
getConfiguration() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves the configuration currently in use.
getConfiguration() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the configuration component.
getConfiguration() - Method in class org.infinispan.persistence.file.SingleFileStore
 
getConfiguration() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getConfiguration() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
getConfiguration() - Method in class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
getConfiguration() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
getConfiguration() - Method in class org.infinispan.persistence.remote.RemoteStore
 
getConfiguration() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getConfiguration() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
getConfigurationAsProperties() - Method in class org.infinispan.CacheImpl
 
getConflictingTransactionBlocks() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
getConnection(String) - Static method in class org.infinispan.cli.connection.ConnectionFactory
 
getConnection(String) - Method in interface org.infinispan.cli.connection.Connector
 
getConnection(String) - Method in class org.infinispan.cli.connection.jmx.remoting.JMXRemotingConnector
 
getConnection(String) - Method in class org.infinispan.cli.connection.jmx.rmi.JMXRMIConnector
 
getConnection() - Method in interface org.infinispan.cli.Context
 
getConnection() - Method in class org.infinispan.cli.impl.ContextImpl
 
getConnection() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
Fetches a connection from the factory.
getConnection() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ManagedConnectionFactory
 
getConnection() - Method in class org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory
 
getConnection() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
getConnectionCount() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
getConnectionEnvironment(String) - Method in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
getConnectionEnvironment(String) - Method in interface org.infinispan.cli.connection.jmx.JMXUrl
 
getConnectionFactory() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
getConnectionFactory(String, ClassLoader) - Static method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
Constructs a ConnectionFactory based on the supplied class name.
getConnectionFactory(Class<? extends ConnectionFactory>) - Static method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
Constructs a ConnectionFactory based on the supplied class name.
getConnectionFactory() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
getConnectionFactory() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
getConnectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionPool() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConnectionUrl() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
getConnectionUrl() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
getConnectTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConnectTimeout() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConnectTimeout() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getConsistentHash() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
Note that the returned ConsistentHash may not be thread-safe.
getConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
Retrieves the consistent hash instance currently in use, an instance of the configured ConsistentHash class (which defaults to DefaultConsistentHash.
getConsistentHash() - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getConsistentHashAtEnd() - Method in 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
 
getConsistentHashFactory() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getConsistentHashFactory() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getConsistentHashFactory() - Method in class org.infinispan.topology.CacheJoinInfo
 
getContainer() - Method in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
getContainer() - Method in interface org.infinispan.cli.connection.jmx.JMXUrl
 
getContext() - Method in interface org.infinispan.cli.shell.Shell
 
getContext() - Method in class org.infinispan.cli.shell.ShellImpl
 
getContext(String, char[], String, char[]) - Static method in class org.infinispan.commons.util.SslContextFactory
 
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.AbstractDelegatingTransport
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
getCountRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getCreated() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getCreated() - Method in interface org.infinispan.client.hotrod.MetadataValue
 
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.metadata.MetadataMortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
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
 
getCurrentArgument() - Method in class org.infinispan.cli.commands.ProcessedCommand
 
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
 
getCustomInterceptorsBuilder() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
getCWD() - Method in interface org.infinispan.cli.shell.Shell
 
getCWD() - Method in class org.infinispan.cli.shell.ShellImpl
 
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
 
getDatasourceJndiLocation() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
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
getDefaultConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getDefaultExecutorFactoryPoolSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultExecutorFactoryQueueSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultQueueSize(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultRpcOptions(boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
getDefaultRpcOptions(boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Builds a RpcOptions based on the parameters
getDefaultRpcOptions(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getDefaultRpcOptions(boolean, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
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
 
getDefaultTokens() - Method in class org.infinispan.checkstyle.checks.regexp.IllegalImport
 
getDefinedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDelegate() - Method in class org.infinispan.AbstractDelegatingCache
 
getDelegate(AddLuceneWork) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
 
getDelegate(DeleteLuceneWork) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
 
getDelegate(UpdateLuceneWork) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
 
getDelegate(OptimizeLuceneWork) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
 
getDelegate(FlushLuceneWork) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
 
getDelegate(PurgeAllLuceneWork) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
 
getDeleteAllRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getDeleteExpiredRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getDeleteRowSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
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
 
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.configuration.parsing.XmlConfigHelper
Returns the root element of a given input stream
getDriverClass() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
getElapsedTime() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getElementContent(Element, boolean) - Static method in class org.infinispan.configuration.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
 
getEngine(SSLContext, boolean, boolean) - Static method in class org.infinispan.commons.util.SslContextFactory
 
getEnlistedResources() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getEnlistedSynchronization() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
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, TimeService) - Method in class org.infinispan.persistence.support.Bucket
 
getErroneousAttributes() - Method in exception org.infinispan.commons.CacheConfigurationException
 
getEvictionManager() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getEvictionManager() - Method in interface org.infinispan.AdvancedCache
 
getEvictionManager() - Method in class org.infinispan.CacheImpl
 
getEvictions() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getEvictions() - Method in interface org.infinispan.stats.Stats
 
getEvictions() - Method in class org.infinispan.stats.StatsImpl
 
getException() - Method in class org.infinispan.commons.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.
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getExclusiveWriteLock() - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
getExclusiveWriteLock() - Method in class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
getExecutor(Properties) - Method in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
getExecutor(Properties) - Method in interface org.infinispan.commons.executors.ExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.WithinThreadExecutorFactory
 
getExecutorService() - Method in interface org.infinispan.distexec.mapreduce.MapReduceManager
ExecutorService provided for local task execution
getExecutorService() - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
getExpiryTime() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
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 interface org.infinispan.container.entries.InternalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getExpiryTime(InternalMetadata) - Static method in class org.infinispan.persistence.PersistenceUtil
 
getExternalizer(Class<?>) - Method in class org.infinispan.commons.marshall.jboss.SerializeWithExtFactory
 
getExternalizer(Class<?>) - Method in class org.infinispan.marshall.core.SerializeWithExtFactory
 
getFacetManager() - Method in interface org.infinispan.query.CacheQuery
 
getFacetManager() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
getFactory() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns the factory used for constructing new workers.
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
 
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
 
getFetchedValue() - Method in class org.infinispan.query.clustered.QueryResponse
 
getFetchMode() - Method in class org.infinispan.query.FetchOptions
 
getFetchSize() - Method in class org.infinispan.persistence.jdbc.TableManipulation
For DB queries the fetch size will be set on ResultSet.setFetchSize(int).
getFetchSize() - Method in class org.infinispan.query.FetchOptions
 
getField(String, Class<?>) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
getFile(String) - Method in class org.infinispan.io.GridFilesystem
Returns the file denoted by pathname.
getFile(String, int) - Method in class org.infinispan.io.GridFilesystem
Returns the file denoted by pathname.
getFile(String, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(String, String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String, int) - Method in class org.infinispan.io.GridFilesystem
 
getFileList() - Method in class org.infinispan.lucene.impl.FileListOperations
 
getFileMetadata(String) - Method in class org.infinispan.lucene.impl.FileListOperations
 
getFileName() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the fileName.
getFileName() - Method in class org.infinispan.lucene.FileCacheKey
Get the fileName.
getFileName() - Method in class org.infinispan.lucene.FileReadLockKey
Get the fileName.
getFilePointer() - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
getFilePointer() - Method in class org.infinispan.lucene.impl.SingleChunkIndexInput
 
getFilterCondition() - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
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.
getFirstChildElement(Element) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
Gets the first child element of an element
getFirstException() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getFirstInChain() - Method in class org.infinispan.interceptors.InterceptorChain
 
getFlagInt() - Method in enum org.infinispan.client.hotrod.Flag
 
getFlags() - Method in class org.infinispan.commands.AbstractLocalFlagAffectedCommand
 
getFlags() - Method in class org.infinispan.commands.control.LockControlCommand
 
getFlags() - Method in interface org.infinispan.commands.LocalFlagAffectedCommand
 
getFlags() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getFlags() - Method in class org.infinispan.DecoratedCache
 
getForceReturnValues() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getForkJoinTaskTag() - Method in class org.infinispan.commons.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
 
getGlobalComponentRegistry() - Method in class org.infinispan.factories.ComponentRegistry
 
getGlobalComponentRegistry() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getGlobalComponentRegistry() - Method in class org.infinispan.manager.DefaultCacheManager
 
getGlobalComponentRegistry() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getGlobalConfiguration() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getGlobalConfigurationAsProperties() - Method in class org.infinispan.manager.DefaultCacheManager
getGlobalConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getGlobalKeySet(Cache<K, V>) - Static method in class org.infinispan.tasks.GlobalKeySetTask
 
getGlobalTransaction() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getGlobalTransaction() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
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 class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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
 
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
 
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
 
getHSearchProjection() - Method in class org.infinispan.query.impl.ProjectionConverter
 
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.client.hotrod.impl.transport.tcp.TcpTransport
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash2.Externalizer
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash2Compat.Externalizer
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
getId() - Method in class org.infinispan.commons.io.ByteBufferImpl.Externalizer
 
getId() - Method in class org.infinispan.commons.marshall.AbstractExternalizer
 
getId() - Method in interface org.infinispan.commons.marshall.AdvancedExternalizer
Returns an integer that identifies the externalizer type.
getId() - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
getId() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
getId() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
getId() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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.metadata.MetadataImmortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.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.versioning.NumericVersion.Externalizer
 
getId() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.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.lucene.ChunkCacheKey.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
getId() - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
getId() - Method in interface org.infinispan.marshall.AdvancedExternalizer
Deprecated.
Returns an integer that identifies the externalizer type.
getId() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshalledValue.Externalizer
 
getId() - Method in class org.infinispan.marshall.exts.ArrayExternalizers.ListArray
 
getId() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.ListExternalizer
 
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.LegacyAdvancedExternalizerAdapter
Deprecated.
 
getId() - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
getId() - Method in class org.infinispan.metadata.InternalMetadataImpl.Externalizer
 
getId() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getId() - Method in class org.infinispan.registry.ScopedKey.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.KeyValuePair.Externalizer
 
getIdentifierQuoteString() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getIgnoreExtraResponseFilter(Collection<Address>) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
getIndex() - Method in interface org.infinispan.query.clustered.ClusteredDoc
 
getIndex() - Method in class org.infinispan.query.clustered.ClusteredFieldDoc
 
getIndex() - Method in class org.infinispan.query.clustered.ClusteredScoreDoc
 
getIndexedClassNames() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getIndexManagerFactory() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getIndexName() - Method in class org.infinispan.lucene.ChunkCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileListCacheKey
Get the indexName.
getIndexName() - Method in class org.infinispan.lucene.FileReadLockKey
Get the indexName.
getIndexName() - Method in interface org.infinispan.lucene.impl.DirectoryExtensions
 
getIndexName() - Method in interface org.infinispan.lucene.IndexScopedKey
 
getIndexName() - Method in class org.infinispan.lucene.InfinispanDirectory
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.commons.marshall.jboss.ExtendedRiverUnmarshaller
 
getInjectMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getInput(String) - Method in class org.infinispan.io.GridFilesystem
Opens an InputStream for reading from the file denoted by pathname.
getInput(File) - Method in class org.infinispan.io.GridFilesystem
Opens an InputStream for reading from the given file.
getInsertRowSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getInstance() - Static method in class org.infinispan.commons.equivalence.AnyEquivalence
 
getInstance(Class<T>) - Static method in class org.infinispan.commons.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.commons.util.Util
Instantiates a class based on the class name provided.
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(AdvancedCache<?, ?>) - Static method in class org.infinispan.query.backend.KeyTransformationHandler
Gets the KeyTransformationHandler instance used by the supplied cache.
getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
getInstance() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getInstanceStrict(Class<T>) - Static method in class org.infinispan.commons.util.Util
Similar to Util.getInstance(Class) except that exceptions are propagated to the caller.
getInstanceStrict(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
Similar to Util.getInstance(String, ClassLoader) except that exceptions are propagated to the caller.
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.
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
getInternalId() - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
 
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
 
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
getInternalId() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
Each xid has a unique long object associated to it.
getIntProperty(String, int) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getIntProperty(String, int) - Method in class org.infinispan.commons.util.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getIntStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getIntStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getInvalidations() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getInvocationContext(boolean) - Method in interface org.infinispan.context.InvocationContextContainer
Returns the InvocationContext that is currently associated with the calling thread.
getInvocationContext(boolean) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
getInvocationContextContainer() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getInvocationContextContainer() - Method in interface org.infinispan.AdvancedCache
Deprecated.
This method may be removed in a future version of Infinispan.
getInvocationContextContainer() - Method in class org.infinispan.CacheImpl
 
getJavaClass() - Method in class org.infinispan.query.remote.client.QueryRequestMarshaller
 
getJavaClass() - Method in class org.infinispan.query.remote.client.QueryResponseMarshaller
 
getJavaClass() - Method in class org.infinispan.query.remote.client.SortCriteriaMarshaller
 
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.
getJmxObjectName() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getJMXServiceURL() - Method in interface org.infinispan.cli.connection.jmx.JMXUrl
 
getJMXServiceURL() - Method in class org.infinispan.cli.connection.jmx.remoting.JMXRemotingUrl
 
getJMXServiceURL() - Method in class org.infinispan.cli.connection.jmx.rmi.JMXRMIUrl
 
getJoiners() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getJoinInfo() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getJpqlString() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getJpqlString() - Method in class org.infinispan.query.remote.client.QueryRequest
 
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.commons.util.AbstractMap.SimpleEntry
 
getKey() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
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 interface org.infinispan.marshall.core.MarshalledEntry
Returns the same key as MarshalledEntry.getKeyBytes(), but unmarshalled.
getKey() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
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.persistence.modifications.Remove
 
getKey() - Method in class org.infinispan.persistence.modifications.Store
 
getKey() - Method in class org.infinispan.registry.ScopedKey
 
getKey() - Method in exception org.infinispan.transaction.WriteSkewException
 
getKey() - Method in class org.infinispan.util.KeyValuePair
 
getKeyBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
Returns the key in serialized format.
getKeyBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
getKeyEquivalence() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
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.lucene.LuceneKey2StringMapper
This method has to perform the inverse transformation of the keys used in the Lucene Directory from String to object.
getKeyMapping(String) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
getKeyMapping(String) - Method in class org.infinispan.persistence.keymappers.MarshalledValueOrPrimitiveMapper
 
getKeyMapping(String) - Method in interface org.infinispan.persistence.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
 
getKeysInTransit() - Method in class org.infinispan.persistence.async.State
 
getKeySizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeyStoreFileName() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeyStorePassword() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeyTransformationHandler() - Method in class org.infinispan.query.backend.QueryInterceptor
 
getKeyType() - Method in interface org.infinispan.distribution.group.Grouper
 
GetKeyValueCommand - Class in org.infinispan.commands.read
Implements functionality defined by Map.get(Object) and Map.containsKey(Object) operations
GetKeyValueCommand(Object, Set<Flag>, boolean) - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
GetKeyValueCommand() - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
getLastModified() - Method in class org.infinispan.lucene.FileMetadata
 
getLastUsed() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getLastUsed() - Method in interface org.infinispan.client.hotrod.MetadataValue
 
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.metadata.MetadataMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
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 interface org.infinispan.commons.io.ByteBuffer
Length bytes, starting from offset, within the underlying byte[] (as returned by ByteBuffer.getBuf() are owned by this buffer instance.
getLength() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getLength() - Method in class org.infinispan.io.GridFile.Metadata
 
getLength() - Static method in class org.infinispan.Version
 
getLifespan() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getLifespan() - Method in interface org.infinispan.client.hotrod.MetadataValue
 
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.metadata.MetadataMortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
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
 
getList() - Method in class org.infinispan.persistence.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
 
getLoadAllKeysBinarySql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getLoadAllKeysStringSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getLoadAllRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getLoadNonExpiredAllRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getLoadSomeRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
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
 
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.
getLocalName() - Method in enum org.infinispan.persistence.cli.configuration.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.cli.configuration.Element
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.jdbc.configuration.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.jdbc.configuration.Element
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.remote.configuration.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.remote.configuration.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
 
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(FlagAffectedCommand, boolean) - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
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 class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
getLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getLockedKeysForRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
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
 
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 interface org.infinispan.client.hotrod.impl.protocol.Codec
Logger for Hot Rod client codec
getLog() - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
getLog() - Method in class org.infinispan.client.hotrod.impl.protocol.Codec11
 
getLog() - Method in class org.infinispan.client.hotrod.impl.protocol.Codec12
 
getLog(Class<?>) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
getLog(Class<?>) - Static method in class org.infinispan.commons.logging.BasicLogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.commons.logging.BasicLogFactory
 
getLog(Class<?>) - Static method in class org.infinispan.commons.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.commons.logging.LogFactory
 
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.CacheWriterInterceptor
 
getLog() - Method in class org.infinispan.interceptors.CallInterceptor
 
getLog() - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
getLog() - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
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.totalorder.TotalOrderDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.TxInterceptor
 
getLog() - Method in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
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.query.backend.LocalQueryInterceptor
 
getLog() - Method in class org.infinispan.query.backend.QueryInterceptor
 
getLog() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
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.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLongProperty(String, long) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getLongProperty(String, long, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
getLongProperty(String, long) - Method in class org.infinispan.commons.util.TypedProperties
 
getLongProperty(String, long, boolean) - Method in class org.infinispan.commons.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.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
 
getMap() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMappedValue() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
Returns the default mapped value for additions, or null if additions are not supported.
getMapper() - Method in class org.infinispan.commands.read.MapCombineCommand
 
getMarshalledEntryFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getMarshalledEntryFactory() - Method in class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
getMarshalledEntryFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
To be used for building MarshalledEntry objects.
getMarshaller() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getMarshaller() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getMarshaller() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getMarshaller() - Method in class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
getMarshaller() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getMarshaller() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getMassIndexer() - Method in class org.infinispan.query.impl.SearchManagerImpl
 
getMassIndexer() - Method in interface org.infinispan.query.SearchManager
The MassIndexer can be used to rebuild the Lucene indexes from the entries stored in Infinispan.
getMaxDoublingSize() - Method in class org.infinispan.commons.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%.
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
Deprecated.
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxIdle() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getMaxIdle() - Method in interface org.infinispan.client.hotrod.MetadataValue
 
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.metadata.MetadataMortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
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
 
getMaxNumberOfKeys() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
getMaxResults() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getMaxResults() - Method in class org.infinispan.query.remote.client.QueryRequest
 
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
 
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.AbstractDelegatingTransport
 
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
 
getMetadata() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
getMetadata() - Method in class org.infinispan.commands.control.LockControlCommand
 
getMetadata() - Method in interface org.infinispan.commands.MetadataAwareCommand
Get metadata of this command.
getMetadata() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getMetadata() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getMetadata() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMetadata() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getMetadata() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getMetadata() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getMetadata() - Method in interface org.infinispan.container.entries.metadata.MetadataAware
Get metadata of this cache entry.
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getMetadata() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getMetadata() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
 
getMetadata() - Method in interface org.infinispan.marshall.core.MarshalledEntry
 
getMetadata() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
getMetadataBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
 
getMetadataBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
getMetadataFilename() - Method in interface org.infinispan.factories.components.ModuleMetadataFileFinder
 
getMetadataFilename() - Method in class org.infinispan.query.impl.QueryMetadataFileFinder
 
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
 
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
 
getModifications() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getModifications() - Method in interface org.infinispan.commands.tx.totalorder.TotalOrderPrepareCommand
 
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
 
getModuleCommandFactory() - Method in class org.infinispan.query.impl.QueryModuleCommandExtensions
 
getModuleCommandInitializer() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
getModuleCommandInitializer() - Method in class org.infinispan.query.impl.QueryModuleCommandExtensions
 
getModuleCommandInitializers() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getModuleCommands() - Method in interface org.infinispan.commands.module.ModuleCommandFactory
Provides a map of command IDs to command types of all the commands handled by the command factory instance.
getModuleCommands() - Method in class org.infinispan.query.impl.CommandFactory
 
getModuleMetadataFiles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
Retrieves an Iterable containing metadata file finders declared by each module.
getModuleProperties() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getMyId() - Method in class org.infinispan.query.clustered.QueryBox
Id of this QueryBox
getName() - Method in class org.infinispan.AbstractDelegatingCache
 
getName() - Method in class org.infinispan.CacheImpl
 
getName() - Method in class org.infinispan.cli.commands.client.Connect
 
getName() - Method in class org.infinispan.cli.commands.client.Container
 
getName() - Method in class org.infinispan.cli.commands.client.Disconnect
 
getName() - Method in class org.infinispan.cli.commands.client.Help
 
getName() - Method in class org.infinispan.cli.commands.client.Quit
 
getName() - Method in interface org.infinispan.cli.commands.Command
 
getName() - Method in class org.infinispan.cli.commands.server.Abort
 
getName() - Method in class org.infinispan.cli.commands.server.Begin
 
getName() - Method in class org.infinispan.cli.commands.server.Cache
 
getName() - Method in class org.infinispan.cli.commands.server.Clear
 
getName() - Method in class org.infinispan.cli.commands.server.Commit
 
getName() - Method in class org.infinispan.cli.commands.server.Create
 
getName() - Method in class org.infinispan.cli.commands.server.Encoding
 
getName() - Method in class org.infinispan.cli.commands.server.End
 
getName() - Method in class org.infinispan.cli.commands.server.Evict
 
getName() - Method in class org.infinispan.cli.commands.server.Get
 
getName() - Method in class org.infinispan.cli.commands.server.Info
 
getName() - Method in class org.infinispan.cli.commands.server.Locate
 
getName() - Method in class org.infinispan.cli.commands.server.Ping
 
getName() - Method in class org.infinispan.cli.commands.server.Put
 
getName() - Method in class org.infinispan.cli.commands.server.Remove
 
getName() - Method in class org.infinispan.cli.commands.server.Replace
 
getName() - Method in class org.infinispan.cli.commands.server.Rollback
 
getName() - Method in class org.infinispan.cli.commands.server.Site
 
getName() - Method in class org.infinispan.cli.commands.server.Start
 
getName() - Method in class org.infinispan.cli.commands.server.Stats
 
getName() - Method in class org.infinispan.cli.commands.server.Upgrade
 
getName() - Method in class org.infinispan.cli.commands.server.Version
 
getName() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getName() - Method in interface org.infinispan.commons.api.BasicCache
Retrieves the name of the cache
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 class org.infinispan.persistence.cli.upgrade.CLInterfaceTargetMigrator
 
getName() - Method in class org.infinispan.persistence.jdbc.TableName
 
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.commons.io.ExposedByteArrayOutputStream
Gets the number of bytes to which the internal buffer should be resized.
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
Deprecated.
Gets the number of bytes to which the internal buffer should be resized.
getNewInstance() - Method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
 
getNewMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
getNewMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
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.
getNext() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getNextPosition() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
getNodeAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNodeAddress() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getNodeUuid() - Method in interface org.infinispan.query.clustered.ClusteredDoc
 
getNodeUuid() - Method in class org.infinispan.query.clustered.ClusteredFieldDoc
 
getNodeUuid() - Method in class org.infinispan.query.clustered.ClusteredScoreDoc
 
getNodeUUID() - Method in class org.infinispan.query.clustered.QueryResponse
 
getNonCacheComponents(Set<AbstractComponentRegistry.Component>) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
getNormalizedHash(Object) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
Computes hash code of a given object, and then normalizes it to ensure a positive value is always returned.
getNormalizedHash(Object) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
getNormalizedHash(Object, Hash) - Static method in class org.infinispan.commons.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.
getNormalizedHash(Object) - Method in class org.infinispan.distribution.ch.DefaultConsistentHash
 
getNumberOfChunks() - Method in class org.infinispan.lucene.FileMetadata
 
getNumberOfEntries() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getNumberOfIndexedEntities(String) - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
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
 
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 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
 
getNumResults() - Method in class org.infinispan.query.remote.client.QueryResponse
 
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
 
getObjectLoadingExecutionAvgTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectLoadingExecutionMaxTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectLoadingTotalTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
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
 
getObjectsLoadedCount() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectWriter(Object) - Method in class org.infinispan.marshall.core.ExternalizerTable
 
getOfflineStatus(String) - Method in interface org.infinispan.xsite.BackupSender
 
getOfflineStatus(String) - Method in class org.infinispan.xsite.BackupSenderImpl
 
getOffset() - Method in interface org.infinispan.cli.commands.Argument
 
getOffset() - Method in class org.infinispan.cli.commands.Parameter
 
getOffset() - Method in interface org.infinispan.commons.io.ByteBuffer
Returns the offset within the underlying byte[] (as returned by ByteBuffer.getBuf() owned by this buffer instance.
getOffset() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
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
 
getOldValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Regardless of whether isPre() is true or is false, this method returns the value of the entry being deleted.
getOldValue() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
GetOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "get" operation as described by Hot Rod protocol specification.
GetOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetOperation
 
getOperationMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
getOperationName() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getOperationName() - Method in class org.infinispan.jmx.IspnMBeanOperationInfo
 
getOperationsFactory() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getOptions() - Method in class org.infinispan.cli.commands.AbstractCommand
 
getOptions() - Method in interface org.infinispan.cli.commands.Command
 
getOptions() - Method in class org.infinispan.cli.commands.server.Encoding
 
getOptions() - Method in class org.infinispan.cli.commands.server.Get
 
getOptions() - Method in class org.infinispan.cli.commands.server.Locate
 
getOptions() - Method in class org.infinispan.cli.commands.server.Put
 
getOptions() - Method in class org.infinispan.cli.commands.server.Replace
 
getOptions() - Method in class org.infinispan.cli.commands.server.Site
 
getOptions() - Method in class org.infinispan.cli.commands.server.Stats
 
getOptions() - Method in class org.infinispan.cli.commands.server.Upgrade
 
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.
getOrCreateState() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
getOrCreateState() - Method in interface org.infinispan.commands.tx.totalorder.TotalOrderPrepareCommand
returns the TotalOrderRemoteTransactionState associated with this transaction, creating one if no one was associated to this transaction.
getOrCreateState() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
getOrDefault(Object, V) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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
 
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.
getOutputAdapter() - Method in interface org.infinispan.cli.Context
 
getOutputAdapter() - Method in class org.infinispan.cli.impl.ContextImpl
 
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
 
getOwnedPerCapacity(Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
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(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
getOwners(Collection<Object>) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getOwners(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
getOwners(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
getOwners(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.commons.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.factories.components.ComponentMetadata.InjectMetadata
 
getParameters() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
getParameters() - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
getPassword() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
getPassword() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
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.commons.util.concurrent.jdk8backported.CountedCompleter
Returns the current pending count.
getPendingViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getPersistenceExecutor() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getPhysicalAddresses() - Method in class org.infinispan.manager.DefaultCacheManager
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getPhysicalAddresses() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's physical network addresses.
getPingOnStartup() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getPool() - Static method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPooledDataSource() - Method in class org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory
 
getPoolIndex() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinWorkerThread
Returns the index number of this thread in its pool.
getPoolSize() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPreparedTransaction(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Local call returning the remote transaction identified by the supplied xid or null.
getPreparedTransaction(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getPreparedTransactionsFromCluster() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Returns the list of transactions in prepared state from both local and remote cluster nodes.
getPreparedTransactionsFromCluster() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getPrepares() - Method in class org.infinispan.interceptors.TxInterceptor
 
getPrepareStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
getPrimaryLocation(Object) - Method in interface org.infinispan.distribution.DistributionManager
Returns the first Address containing the key.
getPrimaryLocation(Object) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.OwnershipStatistics
 
getPrimaryOwnedPerCapacity(Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
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
 
getPriority() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
getProgrammaticMapping() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProjection() - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
getProjectionSize() - Method in class org.infinispan.query.remote.client.QueryResponse
 
getPrompt() - Method in interface org.infinispan.cli.Config
 
getPrompt() - Method in class org.infinispan.cli.shell.ConfigImpl
 
getProperties() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getProperties() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
getProperties() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProperty(String) - Method in interface org.infinispan.cli.Context
 
getProperty(String) - Method in class org.infinispan.cli.impl.ContextImpl
 
getProperty(String, String, boolean) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
Get the property associated with the key, optionally applying string property replacement as defined in StringPropertyReplacer.replaceProperties(java.lang.String) to the result.
getProperty(String, String) - Static method in class org.infinispan.commons.util.LegacyKeySupportSystemProperties
 
getProperty(String, String, String) - Static method in class org.infinispan.commons.util.LegacyKeySupportSystemProperties
 
getProperty(String, String) - Static method in class org.infinispan.commons.util.SysPropertyActions
 
getProperty(String) - Static method in class org.infinispan.commons.util.SysPropertyActions
 
getProperty(String, String, boolean) - Method in class org.infinispan.commons.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.
getProperty(String) - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getProtocolVersion() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getProtocolVersion() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getProtocolVersion() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the HotRod protocol version supported by this RemoteCache implementation
getProtocolVersion() - Static method in class org.infinispan.client.hotrod.Version
 
getProvidedServices() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getQuery(Query, Class<?>...) - Method in class org.infinispan.query.impl.SearchManagerImpl
 
getQuery(Query, Class<?>...) - Method in interface org.infinispan.query.SearchManager
This is a simple method that will just return a CacheQuery, filtered according to a set of classes passed in.
getQueryBox() - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
getQueryFactory(RemoteCache) - Static method in class org.infinispan.client.hotrod.Search
 
getQueryFactory() - Method in class org.infinispan.query.impl.SearchManagerImpl
 
getQueryFactory() - Method in interface org.infinispan.query.SearchManager
Experimental! Obtains the factory for DSL-based queries.
getQueryInterceptor(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getQueuedSubmissionCount() - Method in class org.infinispan.commons.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.commons.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.commons.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.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.core.MarshalledValue
 
getRawBuffer() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
Gets the internal buffer array.
getRawBuffer() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
Gets the internal buffer array.
getRawResult() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Returns the result of the computation.
getRawResult() - Method in class org.infinispan.commons.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
 
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
 
getReflectionManager() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Returns an immutable set containing all the components that exists in the repository at this moment.
getRemoteCache() - Method in class org.infinispan.persistence.remote.RemoteStore
 
getRemoteCacheManager() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the RemoteCacheManager that created this cache.
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.
getRemoteMaster() - Method in class org.infinispan.query.indexmanager.InfinispanIndexManager
 
getRemoteSiteNames() - Method in exception org.infinispan.xsite.BackupFailureException
 
getRemoteSocketAddress() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
getRemoteSocketAddress() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
Returns the address of the endpoint this transport is connected to, or null if it is unconnected.
getRemoteTransaction() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
getRemoteTransaction() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getRemoteTransaction() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderCommitCommand
 
getRemoteTransaction() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderRollbackCommand
 
getRemoteTransaction() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedCommitCommand
 
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
 
getRequestBalancingStrategy() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DefaultResponseGenerator
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DistributionResponseGenerator
 
getResponse(CacheRpcCommand, Object) - Method in interface org.infinispan.remoting.responses.ResponseGenerator
 
getResponseGenerator() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(ResponseGenerator.class);
getResponseValue() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
getResults() - Method in class org.infinispan.query.remote.client.QueryResponse
 
getResultSize() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getResultSize() - Method in interface org.infinispan.query.CacheQuery
Gets the total number of results matching the query, ignoring pagination (firstResult, maxResult).
getResultSize() - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
getResultSize(HSQuery, Cache<?, ?>) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
getResultSize() - Method in class org.infinispan.query.clustered.QueryResponse
 
getResultSize() - Method in interface org.infinispan.query.dsl.Query
Gets the total number of results matching the query, ignoring pagination (firstResult, maxResult).
getResultSize() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
getRetrievals() - Method in interface org.infinispan.stats.Stats
 
getRetrievals() - Method in class org.infinispan.stats.StatsImpl
 
getReturnType() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getRollbacks() - Method in class org.infinispan.interceptors.TxInterceptor
 
getRoot() - Method in class org.infinispan.commons.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.
getRootType() - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
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
 
getRpcOptionsBuilder(ResponseMode) - Method in interface org.infinispan.remoting.rpc.RpcManager
This method is equivalent to getRpcOptionsBuilder(responseMode, true)
getRpcOptionsBuilder(ResponseMode, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getRpcOptionsBuilder(ResponseMode) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getRpcOptionsBuilder(ResponseMode, boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getRunningCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getRunningThreadCount() - Method in class org.infinispan.commons.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
 
getSchema() - Method in class org.infinispan.persistence.jdbc.TableName
 
getScope() - Method in class org.infinispan.registry.ScopedKey
 
getSearchFactory() - Method in class org.infinispan.query.backend.QueryInterceptor
 
getSearchFactory() - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
getSearchFactory() - Method in class org.infinispan.query.impl.SearchManagerImpl
 
getSearchFactory() - Method in interface org.infinispan.query.SearchManager
Experimental.
getSearchManager(Cache<?, ?>) - Static method in class org.infinispan.query.Search
 
getSearchQueryExecutionAvgTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryExecutionCount() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryExecutionMaxTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryExecutionMaxTimeQueryString() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryTotalTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchVersion() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchWorkCreator() - Method in class org.infinispan.query.backend.QueryInterceptor
 
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
 
getSegments() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
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
 
getSelectExpiredRowsSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getSelectIdRowSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getSelectRowSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getSelfDeliverFilter() - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
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
 
getSerializationContext() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getSerializationContext() - Method in class org.infinispan.client.hotrod.marshall.ProtoStreamMarshaller
 
getSerializationContext(RemoteCacheManager) - Static method in class org.infinispan.client.hotrod.marshall.ProtoStreamMarshaller
 
getSerializationContext() - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
 
getServer(byte[]) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
getServer(byte[]) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
getServerAddress() - Method in exception org.infinispan.client.hotrod.exceptions.TransportException
 
getServerAddress() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
getServerList() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getServers() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
getServers() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getService() - Method in class org.infinispan.query.backend.ComponentRegistryServiceProvider
 
getSharedLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getSingleKey() - Method in class org.infinispan.commands.control.LockControlCommand
 
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
 
getSize() - Method in class org.infinispan.lucene.FileMetadata
 
getSortCriteria() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getSortCriteria() - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
getSortCriteria() - Method in class org.infinispan.query.remote.client.QueryRequest
 
getSortedMembers() - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory.Builder
 
getSortOrder() - Method in class org.infinispan.query.dsl.impl.SortCriteria
 
getSoTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getSoTimeout() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getSoTimeout() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getSource() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
getSSLContext() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getSSLContext() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getStartMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getStartOffset() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
getStartOffset() - Method in class org.infinispan.query.remote.client.QueryRequest
 
getState() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
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
 
getStateTransferLock() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StateTransferManager.class);
getStateTransferManager() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StateTransferManager.class);
getStateTransferProvider() - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns the store one configured with fetch persistent state, or null if none exist.
getStateTransferProvider() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
Returns whether an interceptor's statistics are being captured.
getStatisticsEnabled() - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Returns whether an interceptor's statistics are being captured.
getStats() - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
getStats() - Method in interface org.infinispan.AdvancedCache
Returns a Stats object that allows several statistics associated with this cache at runtime.
getStats() - Method in class org.infinispan.CacheImpl
 
getStatsMap() - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatsMap() - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getStatus() - Method in class org.infinispan.AbstractDelegatingCache
 
getStatus() - Method in interface org.infinispan.Cache
 
getStatus() - Method in class org.infinispan.CacheImpl
 
getStatus() - Method in class org.infinispan.factories.AbstractComponentRegistry
Retrieves the state of the registry
getStatus() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStatus() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Get the status of the transaction associated with the calling thread.
getStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
getStatus() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Following values might be returned: - Status.STATUS_PREPARED if the tx is prepared - Status.STATUS_COMMITTED if the tx is committed - Status.STATUS_ROLLEDBACK if the tx is rollback - null otherwise
getStatus() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
The value represent transaction's state as described by the Status field.
getStatusMessagePeriod() - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
getStealCount() - Method in class org.infinispan.commons.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.persistence.support.Bucket
 
getStoredEntries(AdvancedCacheLoader.KeyFilter, TimeService) - Method in class org.infinispan.persistence.support.Bucket
 
getStoredValue() - Method in class org.infinispan.persistence.modifications.Store
 
getStores() - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
getStores() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getStores(Class<T>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
getStores(Class<T>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getStores() - Method in interface org.infinispan.stats.Stats
 
getStores() - Method in class org.infinispan.stats.StatsImpl
 
getStoresAsString() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
getStoresAsString() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getStream() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getStringMapping(Object) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
 
getStringMapping(Object) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
getStringMapping(Object) - Method in interface org.infinispan.persistence.keymappers.Key2StringMapper
Must return an unique String for the supplied key.
getStringMapping(Object) - Method in class org.infinispan.persistence.keymappers.MarshalledValueOrPrimitiveMapper
 
getStringStore() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
getSubElement(Element, String) - Static method in class org.infinispan.configuration.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
 
getSurplusQueuedTaskCount() - Static method in class org.infinispan.commons.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
 
getTableManipulation() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
getTableManipulation() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
getTableName() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getTagContents(Element, String, String, String) - Static method in class org.infinispan.configuration.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
 
getTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getterMethod(Class<?>, Class<?>) - Static method in class org.infinispan.commons.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.commons.util.BeanUtils
Returns a getter for a given class
getThrowable() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getTimeout() - Method in class org.infinispan.topology.CacheJoinInfo
 
getTimeout() - Method in class org.infinispan.xsite.XSiteBackup
 
getTimeService() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
getTimeService() - Method in class org.infinispan.factories.ComponentRegistry
 
getTimeService() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getTimeService() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getTimeService() - Method in class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
getTimeService() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getTimeSinceReset() - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
 
getTimeSinceStart() - Method in class org.infinispan.stats.StatsImpl
 
getTopDocs() - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
getTopDocs() - Method in class org.infinispan.query.clustered.QueryResponse
 
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.StateRequestCommand
 
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
 
getTotalCapacity() - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
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
 
getTotalOrderManager() - Method in class org.infinispan.factories.ComponentRegistry
 
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.
getTransactionIdentifier() - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Returns a JTA transaction.
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 interface org.infinispan.transaction.lookup.TransactionManagerLookup
Returns a new TransactionManager.
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
 
getTransactionState() - Method in class org.infinispan.transaction.RemoteTransaction
 
getTransactionSynchronizationRegistry() - Method in interface org.infinispan.transaction.lookup.TransactionSynchronizationRegistryLookup
Returns a new TransactionSynchronizationRegistry.
getTransactionSynchronizedBlock() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
getTransactionTimeout() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetKeysOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.BulkGetOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.ClearOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.FaultTolerantPingOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.QueryOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
getTransport(int) - Method in class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
getTransport() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransport(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransport() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransport(byte[]) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getTransport() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
getTransport() - Method in class org.infinispan.manager.DefaultCacheManager
 
getTransport() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getTransport() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTransport() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTransportCount() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
getTransportCount() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
getTransportFactory() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
getTrustStoreFileName() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTrustStorePassword() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getType() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
getType() - Method in class org.infinispan.factories.components.JmxOperationParameter
 
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.persistence.modifications.Clear
 
getType() - Method in interface org.infinispan.persistence.modifications.Modification
 
getType() - Method in class org.infinispan.persistence.modifications.ModificationsList
 
getType() - Method in class org.infinispan.persistence.modifications.Remove
 
getType() - Method in class org.infinispan.persistence.modifications.Store
 
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.commons.io.ByteBufferImpl.Externalizer
 
getTypeClasses() - Method in interface org.infinispan.commons.marshall.AdvancedExternalizer
Returns a collection of Class instances representing the types that this AdvancedExternalizer can marshall.
getTypeClasses() - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
getTypeClasses() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
getTypeClasses() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
getTypeClasses() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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.metadata.MetadataImmortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.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.versioning.NumericVersion.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.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.lucene.ChunkCacheKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
getTypeClasses() - Method in interface org.infinispan.marshall.AdvancedExternalizer
Deprecated.
Returns a collection of Class instances representing the types that this AdvancedExternalizer can marshall.
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshalledValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ArrayExternalizers.ListArray
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ListExternalizer
 
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.LegacyAdvancedExternalizerAdapter
Deprecated.
 
getTypeClasses() - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.metadata.InternalMetadataImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.registry.ScopedKey.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.KeyValuePair.Externalizer
 
getTypeName() - Method in class org.infinispan.query.remote.client.QueryRequestMarshaller
 
getTypeName() - Method in class org.infinispan.query.remote.client.QueryResponseMarshaller
 
getTypeName() - Method in class org.infinispan.query.remote.client.SortCriteriaMarshaller
 
getUncaughtExceptionHandler() - Method in class org.infinispan.commons.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
 
getUpdateRowSql() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
getUsableSpace() - Method in class org.infinispan.io.GridFile
 
getUserName() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
getUserName() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
getUserTransaction() - Static method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getUserTransaction() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
 
getUseSSL() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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 interface org.infinispan.cli.commands.Argument
 
getValue() - Method in class org.infinispan.cli.commands.Parameter
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getValue() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
getValue() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getValue() - Method in class org.infinispan.commands.write.RemoveCommand
 
getValue() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
getValue(Object, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
Retrieves the value of a field of an object instance via reflection
getValue() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
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.metadata.MetadataMortalCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getValue() - Method in interface org.infinispan.marshall.core.MarshalledEntry
Returns the same value as MarshalledEntry.getKeyBytes(), but unmarshalled.
getValue() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
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.CacheEntryCreatedEvent
Retrieves the value of the entry being created.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvictedEvent
Deprecated.
Retrieves the value of the entry being evicted.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryInvalidatedEvent
Retrieves the value of the entry being activated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryLoadedEvent
Retrieves the value of the entry being loaded.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Retrieves the value of the entry being modified.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryPassivatedEvent
Retrieves the value of the entry being passivated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Retrieves the value of the entry being deleted.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryVisitedEvent
Retrieves the value of the entry being visited.
getValue() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
getValue(int, Address, UUID) - Method in class org.infinispan.query.clustered.ClusteredQueryInvoker
Retrieves the value (using doc index) in a remote query instance
getValue(UUID, int) - Method in class org.infinispan.query.clustered.QueryBox
Get the "docIndex" value on the correct DocumentExtractor
getValue() - Method in class org.infinispan.util.KeyValuePair
 
getValueBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
Returns the value in serialize format.
getValueBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
getValueEquivalence() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
getValueMatcher() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.ClearCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.PutMapCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.RemoveCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getValueMatcher() - Method in interface org.infinispan.commands.write.WriteCommand
 
getValueSizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getVersion() - Method in class org.infinispan.AbstractDelegatingCache
 
getVersion() - Method in class org.infinispan.CacheImpl
Returns the cache configuration as XML string.
getVersion() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getVersion() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
getVersion() - Method in interface org.infinispan.commons.api.BasicCache
Retrieves the version of Infinispan
getVersion() - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
getVersion() - Method in interface org.infinispan.container.entries.versioned.Versioned
 
getVersion() - Method in class org.infinispan.container.versioning.NumericVersion
 
getVersion() - Method in class org.infinispan.manager.DefaultCacheManager
 
getVersioned(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersioned(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the VersionedValue associated to the supplied key param, or null if it doesn't exist.
getVersionShort() - Static method in class org.infinispan.Version
 
getVersionShort(String) - Static method in class org.infinispan.Version
 
getVersionsRead() - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
getVersionsRead() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Note: used in Repeatable Read + Write Skew + Clustering + Versioning.
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.AbstractDelegatingTransport
 
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getViewId() - Method in interface org.infinispan.remoting.transport.Transport
 
getWarningMessage(String, Location) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getWidth() - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
getWidth() - Method in interface org.infinispan.cli.io.IOAdapter
 
getWidth() - Method in class org.infinispan.cli.io.StreamIOAdapter
 
getWithMetadata(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getWithMetadata(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the MetadataValue associated to the supplied key param, or null if it doesn't exist.
GetWithMetadataOperation - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to getWithMetadata operation as described by Hot Rod protocol specification.
GetWithMetadataOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetWithMetadataOperation
 
GetWithVersionOperation - Class in org.infinispan.client.hotrod.impl.operations
Deprecated.
GetWithVersionOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.GetWithVersionOperation
Deprecated.
 
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.
getWritesToTheStores() - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
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_REGISTRY_CACHE_NAME - Static variable in class org.infinispan.registry.ClusterRegistryImpl
 
GLOBAL_TRANSACTION - Static variable in interface org.infinispan.marshall.core.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.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
 
GlobalConfigurationBuilder - Class in org.infinispan.configuration.global
 
GlobalConfigurationBuilder() - Constructor for class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
GlobalConfigurationChildBuilder - Interface in org.infinispan.configuration.global
 
globalId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
Returns a simplified representation of the transaction.
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.
GlobalKeySetTask<K,V> - Class in org.infinispan.tasks
GlobalKeySetTask is a DistributedCallable for obtaining all of the keys across a cluster.
GlobalKeySetTask() - Constructor for class org.infinispan.tasks.GlobalKeySetTask
 
GlobalMarshaller - Class in org.infinispan.marshall.core
A globally-scoped marshaller.
GlobalMarshaller(VersionAwareMarshaller) - Constructor for class org.infinispan.marshall.core.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.Externalizer - Class in org.infinispan.transaction.xa
 
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
 
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.
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() - 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.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
 
gt(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is greater than the given value.
gte(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is greater than or equal to the given value.
GZIP - Static variable in class org.infinispan.commons.util.Base64
Specify that data should be gzip-compressed.

H

handle(CacheRpcCommand, Address, Response, boolean) - Method in interface org.infinispan.remoting.InboundInvocationHandler
Invokes a command on the cache, from a remote source.
handle(CacheRpcCommand, Address, Response, boolean) - Method in class org.infinispan.remoting.InboundInvocationHandlerImpl
 
handle(Message, Response) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
Message contains a Command.
handleAny(ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
Handle an <xs:any>-type nested element, passing in the given value, returning after the end of the element.
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
 
handleConsistentHashUpdate(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
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
 
handleMarshallingException(Throwable, Object) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
handleNewView(List<Address>, boolean, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleNonTxWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
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
 
handleRebalance(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
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
 
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
 
handleStatusRequest(int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
handleUnmarshallingException(Throwable, Class<?>) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
 
handleUnmarshallingException(Throwable) - Method in class org.infinispan.commons.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(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
 
hasEnabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
hasFlag(Flag) - Method in class org.infinispan.commands.AbstractLocalFlagAffectedCommand
 
hasFlag(Flag) - Method in class org.infinispan.commands.control.LockControlCommand
 
hasFlag(Flag) - Method in interface org.infinispan.commands.LocalFlagAffectedCommand
Check whether a particular flag is present in the command
hasFlag(Flag) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
hash - Variable in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
Hash - Interface in org.infinispan.commons.hash
Interface that governs implementations
hash(byte[]) - Method in interface org.infinispan.commons.hash.Hash
Hashes a byte array efficiently.
hash(int) - Method in interface org.infinispan.commons.hash.Hash
An incremental version of the hash function, that spreads a pre-calculated hash code, such as one derived from Object.hashCode().
hash(Object) - Method in interface org.infinispan.commons.hash.Hash
A helper that calculates the hashcode of an object, choosing the optimal mechanism of hash calculation after considering the type of the object (byte array, String or Object).
hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash2
 
hash(int) - Method in class org.infinispan.commons.hash.MurmurHash2
 
hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash2
 
hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
hash(int) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash2Compat
 
hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash3
 
hash(long[]) - Static method in class org.infinispan.commons.hash.MurmurHash3
Hashes a byte array efficiently.
hash(int) - Method in class org.infinispan.commons.hash.MurmurHash3
 
hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash3
 
hash(Object) - Static method in class org.infinispan.commons.util.AbstractMap
 
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_FUNCTION_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
hashCode() - Method in class org.infinispan.atomic.DeltaCompositeKey
 
hashCode() - Method in class org.infinispan.atomic.PutOperation
 
hashCode() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
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.commons.configuration.AbstractTypedPropertiesConfiguration
 
hashCode(Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
 
hashCode(Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
hashCode(Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
Returns a hash code value for the object passed.
hashCode() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Returns the hash code value for this set using the Equivalence function associated with it.
hashCode() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
hashCode() - Method in class org.infinispan.commons.util.AbstractMap
 
hashCode() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
hashCode() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
 
hashCode() - Method in class org.infinispan.commons.util.ForwardingList
 
hashCode() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
hashCode() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
hashCode(byte[], int) - Static method in class org.infinispan.commons.util.Util
A function that calculates hash code of a byte array based on its contents but using the given size parameter as deliminator for the content.
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.CompatibilityModeConfiguration
 
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.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.LockingConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
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.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.container.versioning.NumericVersion
 
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.lucene.ChunkCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileListCacheKey
 
hashCode() - Method in class org.infinispan.lucene.FileMetadata
 
hashCode() - Method in class org.infinispan.lucene.FileReadLockKey
 
hashCode() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
hashCode() - Method in class org.infinispan.marshall.core.MarshalledValue
 
hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
hashCode() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
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.persistence.modifications.ModificationsList
 
hashCode() - Method in class org.infinispan.persistence.modifications.Remove
 
hashCode() - Method in class org.infinispan.persistence.modifications.Store
 
hashCode() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
hashCode() - Method in class org.infinispan.registry.ScopedKey
 
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.rpc.RpcOptions
 
hashCode() - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
 
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.totalorder.TotalOrderLatchImpl
 
hashCode() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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.concurrent.BoundedConcurrentHashMap
 
hashCode() - Method in class org.infinispan.util.KeyValuePair
 
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.
hashNumVirtualNodesDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashNumVirtualNodesDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashNumVirtualNodesDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashNumVirtualNodesDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
hashNumVirtualNodesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashNumVirtualNodesDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
hashNumVirtualNodesDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashNumVirtualNodesDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashNumVirtualNodesDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashNumVirtualNodesDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
hashNumVirtualNodesDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
hashRehashEnabledDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashRehashEnabledDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashRehashEnabledDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashRehashEnabledDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
hashRehashEnabledDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashRehashEnabledDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
hashRehashEnabledDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashRehashEnabledDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashRehashEnabledDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashRehashEnabledDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
hashRehashEnabledDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashRehashRpcTimeoutDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
hashRehashRpcTimeoutDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
hashRehashWaitDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashRehashWaitDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashRehashWaitDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashRehashWaitDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
hashRehashWaitDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashRehashWaitDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
hashRehashWaitDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
hashRehashWaitDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
hashRehashWaitDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
hashRehashWaitDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
hashRehashWaitDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.query.clustered.ClusteredTopDocs
 
hasNext() - Method in class org.infinispan.query.clustered.DistributedIterator
 
hasNext() - Method in class org.infinispan.query.impl.AbstractIterator
 
hasNext() - Method in class org.infinispan.query.impl.NullFilteringIterator
 
hasNext() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
hasQueuedSubmissions() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasScope(S) - Method in class org.infinispan.registry.ScopedKey
 
hasSharedCacheLoaderOrWriter(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
hasSkipLocking(FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
hasTopologyInfo() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
hasUncommittedChanges() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
having(String) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
 
having(String) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
having(String) - Method in class org.infinispan.query.dsl.impl.BaseQueryFactory
 
having(String) - Method in interface org.infinispan.query.dsl.QueryFactory
Creates a condition on the given attribute path that is to be completed later by using it as a sub-condition.
HeaderParams - Class in org.infinispan.client.hotrod.impl.protocol
Hot Rod request header parameters
HeaderParams() - Constructor for class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
HeadersNoCopyrightCheck - Class in org.infinispan.checkstyle.filters
Use a simple CheckStyle rule to make sure no copyright templates are being used: Infinispan uses a single copyright file which can be found in the root of the project.
HeadersNoCopyrightCheck() - Constructor for class org.infinispan.checkstyle.filters.HeadersNoCopyrightCheck
 
Help - Class in org.infinispan.cli.commands.client
 
Help() - Constructor for class org.infinispan.cli.commands.client.Help
 
helpQuiesce() - Static method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.
hexDump(byte[]) - Static method in class org.infinispan.commons.util.Util
 
hexDump(ByteBuffer) - Static method in class org.infinispan.commons.util.Util
 
hexIdHashCode(Object) - Static method in class org.infinispan.commons.util.Util
Prints the identity hash code of the object passed as parameter in an hexadecimal format in order to safe space.
HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get hits.
hookBehavior() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
hookBehavior(ShutdownHookBehavior) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
host() - Method in class org.infinispan.client.hotrod.configuration.ServerConfiguration
 
host(String) - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
host() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
 
host(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
hostname - Variable in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
HOTROD_CLIENT_PROPERTIES - Static variable in class org.infinispan.client.hotrod.RemoteCacheManager
 
HOTROD_STRING_CHARSET - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
HotRodClientException - Exception in org.infinispan.client.hotrod.exceptions
Base class for exceptions reported by the hot rod client.
HotRodClientException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodClientException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
HotRodConstants - Interface in org.infinispan.client.hotrod.impl.protocol
Defines constants defined by Hot Rod specifications.
HotRodEntryMarshaller - Class in org.infinispan.persistence.remote.wrapper
HotRodEntryMarshaller.
HotRodEntryMarshaller(ByteBufferFactory) - Constructor for class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
HotRodOperation - Class in org.infinispan.client.hotrod.impl.operations
Generic Hot Rod operation.
HotRodOperation(Codec, Flag[], byte[], AtomicInteger) - Constructor for class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
HotRodTimeoutException - Exception in org.infinispan.client.hotrod.exceptions
Signals an remote timeout(due to locking) in the infinispan server.
HotRodTimeoutException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
HotRodTimeoutException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
 
hotRodWrapping(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
hotRodWrapping() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
hotRodWrapping(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
hotRodWrapping(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configures this RemoteStore so that it enables all settings needed to create entries to be served by a HotRod endpoint, for example when performing rolling upgrades.
hSearchQuery - Variable in class org.infinispan.query.impl.CacheQueryImpl
 

I

icc - Variable in class org.infinispan.CacheImpl
 
icf - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
icf - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
icf - Variable in class org.infinispan.transaction.TransactionTable
 
ID - Static variable in interface org.infinispan.query.ProjectionConstants
 
id - Variable in class org.infinispan.transaction.xa.GlobalTransaction
 
idColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
idColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The name of the database column used to store the keys
idColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
idColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The type of the database column used to store the keys
Ids - Interface in org.infinispan.commons.marshall
Indexes for object types included in commons.
Ids - Interface in org.infinispan.marshall.core
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
 
ignoreDirectoryProviderProperty(String, String) - Method in interface org.infinispan.query.logging.Log
 
ignoreDirectoryProviderProperty(String, String) - Method in class org.infinispan.query.logging.Log_$logger
 
ignoreDirectoryProviderProperty$str() - Method in class org.infinispan.query.logging.Log_$logger
 
IgnoreExtraResponsesValidityFilter - Class in org.infinispan.remoting.responses
A filter that only expects responses from an initial set of targets.
IgnoreExtraResponsesValidityFilter(Collection<Address>, Address, boolean) - 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.StoreConfiguration
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.
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:
ignoringException(String, String, Throwable) - Method in interface org.infinispan.commons.logging.Log
 
ignoringException(String, String, Throwable) - Method in class org.infinispan.commons.logging.Log_$logger
 
ignoringException(String, String, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
ignoringException(String, String, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ignoringException(String, String, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
ignoringException(String, String, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
ignoringException(String, String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
ignoringException(String, String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringException$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
ignoringException$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
ignoringException$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ignoringException$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
ignoringException$str() - Method in class org.infinispan.query.logging.Log_$logger
 
ignoringException$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringManagedAttribute(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
ignoringManagedAttribute(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ignoringManagedAttribute(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
ignoringManagedAttribute(String) - Method in class org.infinispan.query.logging.Log_$logger
 
ignoringManagedAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
ignoringManagedAttribute(String) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringManagedAttribute$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
ignoringManagedAttribute$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ignoringManagedAttribute$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
ignoringManagedAttribute$str() - Method in class org.infinispan.query.logging.Log_$logger
 
ignoringManagedAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
IllegalImport - Class in org.infinispan.checkstyle.checks.regexp
A simple CheckStyle checker to verify specific import statements are not being used.
IllegalImport() - Constructor for class org.infinispan.checkstyle.checks.regexp.IllegalImport
 
immediateLockForWriting(Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
IMMORTAL_ENTRY - Static variable in interface org.infinispan.marshall.core.Ids
 
IMMORTAL_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
ImmortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is immortal/cannot expire
ImmortalCacheEntry(Object, Object) - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry
 
ImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
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
 
IMMUTABLE_MAP - Static variable in interface org.infinispan.commons.marshall.Ids
 
immutableCollectionCopy(Collection<T>) - Static method in class org.infinispan.commons.util.Immutables
Creates a new immutable copy of the specified Collection.
immutableCollectionWrap(Collection<? extends T>) - Static method in class org.infinispan.commons.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.commons.util.Immutables
Wraps a Map.Entry} with an immutable Map.Entry}.
immutableInternalCacheEntry(InternalCacheEntry) - Static method in class org.infinispan.util.CoreImmutables
Wraps a InternalCacheEntry} with an immutable InternalCacheEntry}.
immutableListConvert(Collection<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
Converts a Collection to an immutable List by copying it.
ImmutableListCopy<E> - Class in org.infinispan.commons.util
A lightweight, read-only copy of a List.
ImmutableListCopy() - Constructor for class org.infinispan.commons.util.ImmutableListCopy
Constructs a new ImmutableListCopy.
ImmutableListCopy(Collection<? extends E>) - Constructor for class org.infinispan.commons.util.ImmutableListCopy
Only one copy constructor since the list is immutable.
ImmutableListCopy(E[]) - Constructor for class org.infinispan.commons.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.commons.util.ImmutableListCopy
Utility constructors to allow combining collections
immutableListCopy(List<T>) - Static method in class org.infinispan.commons.util.Immutables
Creates an immutable copy of the list.
immutableListMerge(List<? extends T>, List<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
Creates a new immutable list containing the union (combined entries) of both lists.
immutableListWrap(T...) - Static method in class org.infinispan.commons.util.Immutables
Wraps an array with an immutable list.
immutableMapCopy(Map<K, V>) - Static method in class org.infinispan.commons.util.Immutables
Creates an immutable copy of the specified map.
immutableMapWrap(Map<? extends K, ? extends V>) - Static method in class org.infinispan.commons.util.Immutables
Wraps a map with an immutable map.
ImmutableMapWrapperExternalizer() - Constructor for class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
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.commons.util
Factory for generating immutable type wrappers.
Immutables() - Constructor for class org.infinispan.commons.util.Immutables
 
Immutables.Immutable - Interface in org.infinispan.commons.util
 
Immutables.ImmutableMapWrapperExternalizer - Class in org.infinispan.commons.util
 
immutableSetConvert(Collection<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
Converts a Collections into an immutable Set by copying it.
immutableSetCopy(Set<T>) - Static method in class org.infinispan.commons.util.Immutables
Creates an immutable copy of the specified set.
immutableSetWrap(Set<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
Wraps a set with an immutable set.
immutableTypedProperties(TypedProperties) - Static method in class org.infinispan.commons.util.Immutables
Creates an immutable copy of the properties.
in(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left operand is equal to one of the (fixed) list of values given as argument.
in(Collection) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left operand is equal to one of the elements from the Collection of values given as argument.
IN_DOUBT_TX_INFO - Static variable in interface org.infinispan.marshall.core.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
 
includeLower(boolean) - Method in interface org.infinispan.query.dsl.RangeConditionContext
 
includeUpper(boolean) - Method in interface org.infinispan.query.dsl.RangeConditionContext
 
incompatibleLoaderConfiguration(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
incompatibleLoaderConfiguration(String, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
incompatibleLoaderConfiguration(String, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
incompatibleLoaderConfiguration(String, String) - Method in class org.infinispan.query.logging.Log_$logger
 
incompatibleLoaderConfiguration(String, String) - Method in interface org.infinispan.util.logging.Log
 
incompatibleLoaderConfiguration(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
incompatibleLoaderConfiguration$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
incompatibleLoaderConfiguration$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
incompatibleLoaderConfiguration$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
incompatibleLoaderConfiguration$str() - Method in class org.infinispan.query.logging.Log_$logger
 
incompatibleLoaderConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Equivalent to add(1).
increment(IncrementableEntryVersion) - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
increment(IncrementableEntryVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
increment(IncrementableEntryVersion) - Method in interface org.infinispan.container.versioning.VersionGenerator
 
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() - 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.
indexedEntitiesCount() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
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
 
indexingCompleted() - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
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.
IndexingMapper - Class in org.infinispan.query.impl.massindex
 
IndexingMapper() - Constructor for class org.infinispan.query.impl.massindex.IndexingMapper
 
IndexingReducer - Class in org.infinispan.query.impl.massindex
This Reduce doesn't really index the entries but forwards them to the appropriate index master; the backend knows how to deal with sharding and this way we avoid unnecessary round trips.
IndexingReducer() - Constructor for class org.infinispan.query.impl.massindex.IndexingReducer
 
IndexInputContext - Class in org.infinispan.lucene.impl
 
IndexInputContext(AdvancedCache<ChunkCacheKey, Object>, FileCacheKey, FileMetadata, SegmentReadLocker) - Constructor for class org.infinispan.lucene.impl.IndexInputContext
 
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.
indexMappingChanged() - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
indexMappingChanged() - Method in class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
indexOf(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
indexOf(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
IndexScopedKey - Interface in org.infinispan.lucene
Mostly used for internal abstraction: common type for all keys which need name scoping for different indexes.
IndexUpdateCommand - Class in org.infinispan.query.indexmanager
Custom RPC command containing an index update request for the Master IndexManager of a specific cache & index.
IndexUpdateCommand(String) - Constructor for class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
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.
infinispanClasses() - Static method in class org.infinispan.commons.util.ClassFinder
 
infinispanClasses(String) - Static method in class org.infinispan.commons.util.ClassFinder
 
InfinispanCollections - Class in org.infinispan.commons.util
Static helpers for Infinispan-specific collections
InfinispanCollections() - Constructor for class org.infinispan.commons.util.InfinispanCollections
 
InfinispanCollections.EmptyList - Class in org.infinispan.commons.util
 
InfinispanCollections.EmptyList.EmptyListExternalizer - Class in org.infinispan.commons.util
 
InfinispanCollections.EmptyMap - Class in org.infinispan.commons.util
 
InfinispanCollections.EmptyMap.EmptyMapExternalizer - Class in org.infinispan.commons.util
 
InfinispanCollections.EmptySet - Class in org.infinispan.commons.util
 
InfinispanCollections.EmptySet.EmptySetExternalizer - Class in org.infinispan.commons.util
 
InfinispanCollections.Function<E,T> - Interface in org.infinispan.commons.util
A function that converts a type into another one.
InfinispanCollections.MapMakerFunction<K,V,E> - Interface in org.infinispan.commons.util
A function that converts an entry into a key/value pair for use in a map.
InfinispanCommandsBackend - Class in org.infinispan.query.indexmanager
An Hibernate Search backend module tailored to delegate index writing to another node in the Infinispan cluster using custom remoting commands.
InfinispanCommandsBackend() - Constructor for class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
InfinispanDirectory - Class in org.infinispan.lucene
Deprecated.
This class will be removed. Use DirectoryBuilder to create Directory instead.
InfinispanDirectory(Cache<?, ?>, Cache<?, ?>, String, LockFactory, int, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
InfinispanDirectory(Cache<?, ?>, String, int, SegmentReadLocker) - Constructor for class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
InfinispanDirectory(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String, int) - Constructor for class org.infinispan.lucene.InfinispanDirectory
Deprecated.
This constructor assumes that three different caches are being used with specialized configurations for each cache usage
InfinispanDirectory(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
InfinispanDirectory(Cache<?, ?>) - Constructor for class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
InfinispanIndexInputV3 - Class in org.infinispan.lucene.impl
Responsible for reading from InfinispanDirectory.
InfinispanIndexInputV3(IndexInputContext) - Constructor for class org.infinispan.lucene.impl.InfinispanIndexInputV3
 
InfinispanIndexInputV4 - Class in org.infinispan.lucene.impl
Responsible for reading from InfinispanDirectory.
InfinispanIndexInputV4(IndexInputContext) - Constructor for class org.infinispan.lucene.impl.InfinispanIndexInputV4
 
InfinispanIndexManager - Class in org.infinispan.query.indexmanager
A custom IndexManager to store indexes in the grid itself.
InfinispanIndexManager() - Constructor for class org.infinispan.query.indexmanager.InfinispanIndexManager
 
InfinispanIndexOutput - Class in org.infinispan.lucene.impl
Responsible for writing to a Directory
InfinispanIndexOutput(AdvancedCache<FileCacheKey, FileMetadata>, AdvancedCache<ChunkCacheKey, Object>, FileCacheKey, int, FileListOperations) - Constructor for class org.infinispan.lucene.impl.InfinispanIndexOutput
 
InfinispanQueryStatisticsInfo - Class in org.infinispan.query.impl
This MBean accumulates query statistics from the Hibernate Search statistics object.
InfinispanQueryStatisticsInfo(SearchFactoryIntegrator) - Constructor for class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
InfinispanQueryStatisticsInfoMBean - Interface in org.infinispan.query.impl
MBean interface as required by JMX rules.
INFINITE_LIFESPAN - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
INFINITE_MAXIDLE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
Info - Class in org.infinispan.cli.commands.server
 
Info() - Constructor for class org.infinispan.cli.commands.server.Info
 
inForkJoinPool() - Static method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
init(String[]) - Method in interface org.infinispan.cli.shell.Shell
 
init(String[]) - Method in class org.infinispan.cli.shell.ShellImpl
 
init(Map<SocketAddress, Set<Integer>>, int, int) - Method in interface org.infinispan.client.hotrod.impl.consistenthash.ConsistentHash
 
init(Configuration) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
init(Map<SocketAddress, Set<Integer>>, int, int) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
init(Marshaller, ExecutorService, OperationsFactory, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
init(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, InvocationContextFactory) - 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, InvocationContextFactory, 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, Configuration) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.PutMapCommand
 
init(CacheNotifier, Configuration) - Method in class org.infinispan.commands.write.RemoveCommand
 
init(CacheNotifier, Configuration) - 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.NumericVersionGenerator
 
init(Cache<?, ?>) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
init(Configuration) - Method in class org.infinispan.context.AbstractInvocationContextFactory
 
init(Configuration, GlobalConfiguration) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
init(Configuration) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
 
init(TransactionManager, TransactionTable, Configuration, BatchContainer) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
init(EmbeddedCacheManager, PersistenceManager, ExecutorService, ClusteringDependentLogic, TimeService, Configuration) - Method in class org.infinispan.distexec.mapreduce.MapReduceManagerImpl
 
init(RpcManager, StateTransferManager) - Method in class org.infinispan.distribution.DistributionManagerImpl
 
init(Configuration, RpcManager, CommandsFactory, ExecutorService, ScheduledExecutorService, TimeService) - Method in class org.infinispan.distribution.L1ManagerImpl
 
init() - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
init(PersistenceManager, InternalEntryFactory, TransactionManager, StreamingMarshaller) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
init(InternalEntryFactory, VersionGenerator, TimeService) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
init(L1Manager, ClusteringDependentLogic, Configuration) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
init(L1Manager, ClusteringDependentLogic, EntryFactory, DataContainer, Configuration, StateTransferLock, CommandsFactory) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
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(EmbeddedCacheManager) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
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(InitializationContext) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
 
init(StreamingMarshaller) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
init(InitializationContext) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
init(InitializationContext) - Method in class org.infinispan.persistence.cli.CLInterfaceLoader
 
init(InitializationContext) - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
init(InitializationContext) - Method in class org.infinispan.persistence.file.SingleFileStore
 
init(InitializationContext) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
init(InitializationContext) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
init(InitializationContext) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
init(InitializationContext) - Method in class org.infinispan.persistence.remote.RemoteStore
 
init(InitializationContext) - Method in interface org.infinispan.persistence.spi.CacheLoader
Used to initialize a cache loader.
init(InitializationContext) - Method in interface org.infinispan.persistence.spi.CacheWriter
Used to initialize a cache loader.
init(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
init(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
init(Cache<?, ?>, HSQuery, UUID, int) - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
init(EmbeddedCacheManager) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
init(Cache, ExecutorService, StateTransferManager, InterceptorChain, InvocationContextFactory, Configuration, RpcManager, TransactionManager, CommandsFactory, PersistenceManager, DataContainer, TransactionTable, StateTransferLock, CacheNotifier, TotalOrderManager, BlockingTaskAwareExecutorService, L1Manager) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
init(Cache, ExecutorService, Configuration, RpcManager, CommandsFactory, CacheNotifier, PersistenceManager, DataContainer, TransactionTable, StateTransferLock, StateConsumer, InternalEntryFactory) - 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(CommandsFactory, InvocationContextFactory, 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, VersionGenerator) - 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, TimeService) - 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.
InitialisationContextDelegate - Class in org.infinispan.persistence.jdbc.mixed
// TODO: Document this
InitialisationContextDelegate(InitializationContext, StoreConfiguration) - Constructor for class org.infinispan.persistence.jdbc.mixed.InitialisationContextDelegate
 
InitializationContext - Interface in org.infinispan.persistence.spi
Aggregates the initialisation state needed by either a CacheLoader or a CacheWriter.
InitializationContextImpl - Class in org.infinispan.persistence
 
InitializationContextImpl(StoreConfiguration, Cache, StreamingMarshaller, TimeService, ByteBufferFactory, MarshalledEntryFactory) - Constructor for class org.infinispan.persistence.InitializationContextImpl
 
initialize(InvocationContextFactory, CommandsFactory, InternalEntryFactory, InterceptorChain, DistributionManager, TransactionTable, Equivalence) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
initialize(CacheNotifier, RecoveryManager) - Method in class org.infinispan.commands.tx.PrepareCommand
 
initialize(EvictionManager, PassivationManager, InternalEntryFactory, ActivationManager, PersistenceManager, TimeService) - Method in class org.infinispan.container.DefaultDataContainer
 
initialize(ScheduledExecutorService, Cache, Configuration, DataContainer, PersistenceManager, CacheNotifier, TimeService) - 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(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
initialize(Cache) - Method in class org.infinispan.query.impl.massindex.IndexingMapper
 
initialize(Cache<?, ?>) - Method in class org.infinispan.query.impl.massindex.IndexingReducer
 
initialize(Properties, WorkerBuildContext, DirectoryBasedIndexManager) - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
initialize(Properties, WorkerBuildContext, DirectoryBasedIndexManager) - Method in class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
initialize(StreamingMarshaller, ExecutorService, ExecutorService, InboundInvocationHandler, CacheManagerNotifier, GlobalComponentRegistry, BackupReceiverRepository, TimeService) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
Initializes the transport with global cache configuration and transport-specific properties.
initialize(RpcManager, Configuration, InvocationContextFactory, InterceptorChain, CacheNotifier, TransactionFactory, TransactionCoordinator, TransactionSynchronizationRegistry, CommandsFactory, ClusteringDependentLogic, Cache, TimeService) - Method in class org.infinispan.transaction.TransactionTable
 
initialize(RecoveryManager) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
initialize(Cache<Object, Object>, TimeService) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
initializeConnectionFactory(ConnectionFactory) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
Keeps a reference to the connection factory for further use.
initializeReplicableCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Initializes a ReplicableCommand read from a data stream with components specific to the target cache instance.
initializeReplicableCommand(ReplicableCommand, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
initializeReplicableCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.commands.module.ModuleCommandInitializer
Initializes a command constructed using ModuleCommandFactory.fromStream(byte, Object[]) with necessary named-cache-specific components.
initializeReplicableCommand(ReplicableCommand, boolean) - Method in class org.infinispan.query.impl.CommandInitializer
 
initialRetryWaitTimeDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
initialRetryWaitTimeDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
initialRetryWaitTimeDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
initialRetryWaitTimeDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
initialRetryWaitTimeDeprecated() - Method in interface org.infinispan.util.logging.Log
 
initialRetryWaitTimeDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
initialRetryWaitTimeDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
initialRetryWaitTimeDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
initialRetryWaitTimeDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
initialRetryWaitTimeDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
initialRetryWaitTimeDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
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(PersistenceManager, Configuration) - Method in class org.infinispan.eviction.ActivationManagerImpl
 
inject(PersistenceManager, CacheNotifier, Configuration, DataContainer, TimeService, MarshalledEntryFactory) - 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(TestDelayFactory.Control) - Method in class org.infinispan.factories.TestDelayFactory
 
inject(Configuration, ActivationManager, ClusteringDependentLogic, DataContainer) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
inject(RpcManager, StateConsumer) - 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.DistCacheWriterInterceptor
 
inject(TransactionTable, TotalOrderManager, ClusteringDependentLogic, BlockingTaskAwareExecutorService) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
 
inject(StateTransferManager) - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
 
inject(Cache, Configuration, InvocationContextContainer, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.core.CacheMarshaller
 
inject(RemoteCommandsFactory, GlobalComponentRegistry, StreamingMarshaller) - Method in class org.infinispan.marshall.core.ExternalizerTable
 
inject(ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
inject(Cache, Configuration, InvocationContextContainer, ExternalizerTable, GlobalConfiguration) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
inject(AdvancedCache<Object, Object>, StreamingMarshaller, Configuration, TransactionManager, TimeService, ExecutorService, ByteBufferFactory, MarshalledEntryFactory) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
inject(GlobalComponentRegistry, Transport, BlockingTaskAwareExecutorService, BlockingTaskAwareExecutorService, 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, TimeService) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
inject(BlockingTaskAwareExecutorService) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
 
injectCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
injectConfiguration(Configuration) - Method in class org.infinispan.interceptors.base.CommandInterceptor
 
injectDependencies(EvictionManager, InvocationContextFactory, InvocationContextContainer, CommandsFactory, InterceptorChain, Configuration, CacheNotifier, ComponentRegistry, TransactionManager, BatchContainer, RpcManager, DataContainer, StreamingMarshaller, DistributionManager, EmbeddedCacheManager, ExecutorService, TransactionTable, RecoveryManager, TransactionCoordinator, LockManager, GlobalConfiguration) - Method in class org.infinispan.CacheImpl
 
injectDependencies(DataContainer, Configuration, CacheNotifier, DistributionManager) - Method in class org.infinispan.container.EntryFactoryImpl
 
injectDependencies() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Injects dependencies into this component.
injectDependencies(PersistenceManager, EntryFactory, CacheNotifier, TimeService, InternalEntryFactory) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
injectDependencies(CommandsFactory, EntryFactory, LockManager, DataContainer, StateTransferManager) - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
injectDependencies(DistributionManager, ClusteringDependentLogic, RemoteValueRetrievedListener) - 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(TransactionManager, TransactionSynchronizationRegistry, Cache, ClusterRegistry<String, Class<?>, Boolean>, DataContainer, ExecutorService) - Method in class org.infinispan.query.backend.QueryInterceptor
 
injectDependencies(ScheduledExecutorService, RpcManager, Configuration, CommandsFactory, Cache) - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
injectDependencies(ScheduledExecutorService, RpcManager, Configuration, CommandsFactory, String) - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
injectDependencies(Transport, Cache, Configuration, ReplicationQueue, CommandsFactory, ExecutorService, LocalTopologyManager, StateTransferManager, TimeService) - 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
 
injectTimeService(TimeService) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
injectTimeService(TimeService) - Method in class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager
 
injectVersionGenerator(VersionGenerator) - Method in class org.infinispan.container.IncrementalVersionableEntryFactoryImpl
 
inputKeys() - Method in interface org.infinispan.distexec.FailoverContext
Returns a list of input keys for this task.
InputStream(InputStream) - Constructor for class org.infinispan.commons.util.Base64.InputStream
Constructs a Base64.InputStream in DECODE mode.
InputStream(InputStream, int) - Constructor for class org.infinispan.commons.util.Base64.InputStream
Constructs a Base64.InputStream in either ENCODE or DECODE mode.
inputTaskKeysEmpty() - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
insertBucket(Bucket) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
INSTANCE - Static variable in class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
INSTANCE - Static variable in class org.infinispan.context.impl.ImmutableContext
 
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
 
INT - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
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
 
IntermediateCompositeKey(String, V) - Constructor for class org.infinispan.distexec.mapreduce.MapReduceManagerImpl.IntermediateCompositeKey
 
INTERNAL_METADATA_ID - Static variable in interface org.infinispan.marshall.core.Ids
 
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.
InternalDirectoryContract - Interface in org.infinispan.lucene.cacheloader
This is not meant as a public API but as an internal contract to make it possible to use different versions of Lucene
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
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer, int, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer, int, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer, int, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer, int, int) - Method in class org.infinispan.query.logging.Log_$logger
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer<?>, int, int) - Method in interface org.infinispan.util.logging.Log
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer, int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
internalExternalizerIdLimitExceeded$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
internalExternalizerIdLimitExceeded$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
internalExternalizerIdLimitExceeded$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
internalExternalizerIdLimitExceeded$str() - Method in class org.infinispan.query.logging.Log_$logger
 
internalExternalizerIdLimitExceeded$str() - Method in class org.infinispan.util.logging.Log_$logger
 
InternalMetadata - Interface in org.infinispan.metadata
 
internalMetadata(InternalCacheEntry) - Static method in class org.infinispan.persistence.PersistenceUtil
 
internalMetadata(InternalCacheValue) - Static method in class org.infinispan.persistence.PersistenceUtil
 
InternalMetadataImpl - Class in org.infinispan.metadata
 
InternalMetadataImpl() - Constructor for class org.infinispan.metadata.InternalMetadataImpl
 
InternalMetadataImpl(InternalCacheEntry) - Constructor for class org.infinispan.metadata.InternalMetadataImpl
 
InternalMetadataImpl(Metadata, long, long) - Constructor for class org.infinispan.metadata.InternalMetadataImpl
 
InternalMetadataImpl.Externalizer - Class in org.infinispan.metadata
 
interruptedAcquiringLock(long, InterruptedException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedAcquiringLock(long, InterruptedException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedAcquiringLock(long, InterruptedException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedAcquiringLock(long, InterruptedException) - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedAcquiringLock(long, InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedAcquiringLock(long, InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedAcquiringLock$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedAcquiringLock$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedAcquiringLock$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedAcquiringLock$str() - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedAcquiringLock$str() - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedRetrievingObjectWriter(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedRetrievingObjectWriter(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedRetrievingObjectWriter(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedRetrievingObjectWriter(String) - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedRetrievingObjectWriter(String) - Method in interface org.infinispan.util.logging.Log
 
interruptedRetrievingObjectWriter(String) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedRetrievingObjectWriter$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedRetrievingObjectWriter$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedRetrievingObjectWriter$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedRetrievingObjectWriter$str() - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedRetrievingObjectWriter$str() - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingAsyncStorePush$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedWaitingAsyncStorePush$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedWaitingAsyncStorePush$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedWaitingAsyncStorePush$str() - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedWaitingAsyncStorePush$str() - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedWaitingForCoordinator(InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingForCoordinator$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
interruptedWaitingForCoordinator$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
interruptedWaitingForCoordinator$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
interruptedWaitingForCoordinator$str() - Method in class org.infinispan.query.logging.Log_$logger
 
interruptedWaitingForCoordinator$str() - Method in class org.infinispan.util.logging.Log_$logger
 
intValue() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
INVALID_MAGIC_OR_MESSAGE_ID_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
invalidate() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
invalidate() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
Invalidates transport instance.
invalidate(InvocationContext, Object) - Method in class org.infinispan.commands.write.InvalidateCommand
 
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
 
invalidateTransport(SocketAddress, Transport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
invalidateTransport(SocketAddress, Transport) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
InvalidationFilterVisitor(int) - Constructor for class org.infinispan.interceptors.InvalidationInterceptor.InvalidationFilterVisitor
 
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
 
InvalidationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
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.
invalidCacheLoaderClass(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidCacheLoaderClass(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidCacheLoaderClass(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidCacheLoaderClass(String) - Method in class org.infinispan.query.logging.Log_$logger
 
invalidCacheLoaderClass(String) - Method in interface org.infinispan.util.logging.Log
 
invalidCacheLoaderClass(String) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidCacheLoaderClass$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidCacheLoaderClass$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidCacheLoaderClass$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidCacheLoaderClass$str() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidCacheLoaderClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidCacheState(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidCacheState(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidCacheState(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidCacheState(String) - Method in class org.infinispan.query.logging.Log_$logger
 
invalidCacheState(String) - Method in interface org.infinispan.util.logging.Log
 
invalidCacheState(String) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidCacheState$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidCacheState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidCacheState$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidCacheState$str() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidCacheState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
invalidConfigurationIndexingWithInvalidation() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation() - Method in interface org.infinispan.util.logging.Log
 
invalidConfigurationIndexingWithInvalidation() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation$str() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in interface org.infinispan.util.logging.Log
 
invalidConfigurationIndexingWithoutModule() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule$str() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidKey2StringMapper(String, String) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
invalidKey2StringMapper(String, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidKey2StringMapper$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidMagicNumber(short, short) - Method in interface org.infinispan.client.hotrod.logging.Log
 
invalidMagicNumber(short, short) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
invalidMagicNumber$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
invalidManagedAttributeMethod(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidManagedAttributeMethod(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidManagedAttributeMethod(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidManagedAttributeMethod(String) - Method in class org.infinispan.query.logging.Log_$logger
 
invalidManagedAttributeMethod(String) - Method in interface org.infinispan.util.logging.Log
 
invalidManagedAttributeMethod(String) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidManagedAttributeMethod$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidManagedAttributeMethod$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidManagedAttributeMethod$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidManagedAttributeMethod$str() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidManagedAttributeMethod$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidMessageId(long, long) - Method in interface org.infinispan.client.hotrod.logging.Log
 
invalidMessageId(long, long) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
invalidMessageId$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
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
 
InvalidResponseException - Exception in org.infinispan.client.hotrod.exceptions
Signals an internal protocol error.
InvalidResponseException() - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
InvalidResponseException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in class org.infinispan.query.logging.Log_$logger
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in interface org.infinispan.util.logging.Log
 
invalidTimeoutValue(Object, Object, Object, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidTimeoutValue$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
invalidTimeoutValue$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
invalidTimeoutValue$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
invalidTimeoutValue$str() - Method in class org.infinispan.query.logging.Log_$logger
 
invalidTimeoutValue$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
InvocationContextContainerImpl - Class in org.infinispan.context
InvocationContextContainer implementation.
InvocationContextContainerImpl() - Constructor for class org.infinispan.context.InvocationContextContainerImpl
 
invocationContextFactory - Variable in class org.infinispan.CacheImpl
 
InvocationContextFactory - Interface in org.infinispan.context
Factory for InvocationContext objects.
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(ForkJoinTask<T>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Performs the given task, returning its result upon completion.
invoke() - Method in class org.infinispan.commons.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.
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(Object, boolean) - Method in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
invokeAccessibly(Object, Method, Object[]) - Static method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.ForkJoinPool
 
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class org.infinispan.commons.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.commons.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.commons.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.
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.distexec.DefaultExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
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, RspFilter, boolean, boolean, boolean) - Method in class org.infinispan.remoting.transport.jgroups.CommandAwareRpcDispatcher
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Collection<Address>, ReplicableCommand, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Collection<Address>, ReplicableCommand, boolean, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Collection<Address>, ReplicableCommand, RpcOptions) - 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, 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, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in interface org.infinispan.remoting.transport.Transport
Invokes an RPC call on other caches in the cluster.
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
this method may be removed in the future. Use #invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
this method may be removed in the future. Use #invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
this method may be removed in the future. Use #invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, boolean, NotifyingNotifiableFuture<Object>, long, boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
this method may be removed in the future. Use #invokeRemotelyInFuture(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions, org.infinispan.util.concurrent.NotifyingNotifiableFuture)
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, RpcOptions, NotifyingNotifiableFuture<Object>) - Method in interface org.infinispan.remoting.rpc.RpcManager
The same as RpcManager.invokeRemotely(java.util.Collection, org.infinispan.commands.ReplicableCommand, RpcOptions) except that the task is passed to the transport executor and a Future is returned.
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
 
invokeRemotelyInFuture(Collection<Address>, ReplicableCommand, RpcOptions, NotifyingNotifiableFuture<Object>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
IOAdapter - Interface in org.infinispan.cli.io
 
ioErrorIntegratingState(IOException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
ioErrorIntegratingState(IOException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ioErrorIntegratingState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ioErrorStoringKeys(IOException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
ioErrorStoringKeys(IOException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ioErrorStoringKeys$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ioErrorUnmarshalling(IOException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
ioErrorUnmarshalling(IOException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ioErrorUnmarshalling$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
is1PcForAutoCommitTransaction(LocalTransaction) - Method in class org.infinispan.transaction.TransactionCoordinator
 
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 class org.infinispan.remoting.responses.KeysValidateFilter
 
isAcceptable(Response, Address) - Method in class org.infinispan.remoting.responses.SelfDeliverFilter
 
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
 
isAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
isAllKeysValidated() - Method in class org.infinispan.remoting.responses.KeysValidateFilter
 
isAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
Tests whether an annotation is present on a class.
isAscending() - Method in class org.infinispan.query.remote.client.QueryRequest.SortCriteria
 
isAssignableFrom(List<Class<?>>, Class<?>) - Static method in class org.infinispan.commons.util.ClassFinder
 
isAssignableFrom(Class<?>) - Static method in class org.infinispan.commons.util.ClassFinder
 
isAsyncBackup() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.client.Connect
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.client.Container
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.client.Disconnect
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.client.Help
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.client.Quit
 
isAvailable(Context) - Method in interface org.infinispan.cli.commands.Command
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.server.AbstractServerCommand
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.server.Ping
 
isAvailable(Context) - Method in class org.infinispan.cli.commands.server.Version
 
isBackupFor(String, String) - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
isBalanced(ConsistentHash) - Method in class org.infinispan.topology.DefaultRebalancePolicy
 
isBlocked() - Method in interface org.infinispan.transaction.totalorder.TotalOrderLatch
 
isBlocked() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 
isCacheReady() - Method in class org.infinispan.persistence.cluster.ClusterLoader
A test to check whether the cache is in its started state.
isCancelled() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.AbstractInProcessFuture
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
isCancelled() - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
isCancelled() - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
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.configuration.cache.CacheMode
 
isClustered() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
isColorEnabled() - Method in interface org.infinispan.cli.Config
 
isColorEnabled() - Method in class org.infinispan.cli.shell.ConfigImpl
 
isCommandComplete() - Method in class org.infinispan.cli.commands.ProcessedCommand
 
isCommitOrRollbackSent() - Method in class org.infinispan.transaction.LocalTransaction
 
isCommitReceived() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
check if the transaction is marked for commit (by the Commit Command)
isComparable(Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
 
isComparable(Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
isComparable(Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
Returns whether the given object is comparable.
isCompletedAbnormally() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedNormally() - Method in class org.infinispan.commons.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.
isConnected() - Method in interface org.infinispan.cli.connection.Connection
 
isConnected() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
isConnected() - Method in interface org.infinispan.cli.Context
 
isConnected() - Method in class org.infinispan.cli.impl.ContextImpl
 
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() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
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
 
isCreated() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Indicates whether the cache entry modification event is the result of the cache entry being created.
isCreated() - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
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.configuration.cache.CacheMode
 
isDistributed() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
isDistributed() - Method in class org.infinispan.topology.CacheJoinInfo
 
isDistributed() - Method in class org.infinispan.topology.ClusterCacheStatus
 
isDone() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
isDone() - Method in class org.infinispan.commons.util.concurrent.AbstractInProcessFuture
 
isDone() - Method in class org.infinispan.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
isDone() - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
isDone() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
 
isDone() - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
isDone() - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
isDone() - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
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.client.hotrod.impl.RemoteCacheImpl
 
isEmpty() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
isEmpty() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
 
isEmpty() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
isEmpty() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Returns true if this set contains no elements.
isEmpty() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
isEmpty() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
isEmpty() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
isEmpty() - Method in class org.infinispan.commons.util.ForwardingList
 
isEmpty() - Method in class org.infinispan.commons.util.ImmutableListCopy
 
isEmpty() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
isEmpty() - Method in class org.infinispan.DecoratedCache
 
isEmpty() - Method in class org.infinispan.persistence.support.Bucket
 
isEmpty() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
isEmpty() - Method in interface org.infinispan.remoting.transport.BackupResponse
 
isEmpty() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
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.ReadOnlyDataContainerBackedKeySet
 
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.remoting.ReplicationQueue
 
isEnabled() - Method in class org.infinispan.remoting.ReplicationQueueImpl
 
isEnabled() - Method in class org.infinispan.xsite.OfflineStatus
 
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.
isEntryRemovedInContext(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
isEntryRemovedInContext(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
isEntryRemovedInContext(Object) - Method in interface org.infinispan.context.InvocationContext
 
isEntryRemovedInContext(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
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
 
isExceptionThrown() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
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.metadata.MetadataMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
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
 
isExpired(long) - Method in interface org.infinispan.metadata.InternalMetadata
 
isExpired(long) - Method in class org.infinispan.metadata.InternalMetadataImpl
 
isExpiredMortal(long, long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
 
isExpiredTransient(long, long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
 
isExpiredTransientMortal(long, long, long, long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
 
isFile() - Method in class org.infinispan.io.GridFile
 
isFile() - Method in class org.infinispan.io.GridFile.Metadata
 
isFinished() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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
 
isHeldExclusively() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
isHidden() - Method in class org.infinispan.io.GridFile
 
isHistoryEnabled() - Method in interface org.infinispan.cli.Config
 
isHistoryEnabled() - Method in class org.infinispan.cli.shell.ConfigImpl
 
isIBMJavaVendor() - Static method in class org.infinispan.commons.util.Util
 
isIdProvidedImplicit() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
isImmutable(Object) - Static method in class org.infinispan.commons.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
 
isIndexed(Class<?>) - Method in class org.infinispan.query.backend.QueryInterceptor
 
isInDoubt() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
A transaction is in doubt if it is prepared and and it is orphan.
isInteractive() - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
isInteractive() - Method in interface org.infinispan.cli.io.IOAdapter
 
isInteractive() - Method in class org.infinispan.cli.io.StreamIOAdapter
 
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.configuration.cache.CacheMode
Returns true if the mode is invalidation, either sync or async.
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.commons.marshall.MarshallableTypeHints
Returns whether the hint on whether a particular type is marshallable or not is available.
isL1Enabled - Variable in class org.infinispan.interceptors.ClusteringInterceptor
 
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() - 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
 
isLocalOnly - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
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
 
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.client.hotrod.marshall.ApacheAvroMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
isMarshallable(Class<?>) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
Returns whether a type can be serialized.
isMarshallable(Object) - Method in interface org.infinispan.commons.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.core.VersionAwareMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
isMarshallable(Object) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
isMarshallable(Object) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
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.StreamingMarshallerAdapter
Deprecated.
 
isMarshallable(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
isMarshallable(Object) - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
 
isMarshallableCandidate(Object) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
isMarshallableCandidate(Object) - Method in class org.infinispan.marshall.core.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
 
isMasterLocal() - Method in class org.infinispan.query.indexmanager.InfinispanCommandsBackend
 
isMergeView() - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
isMergeView() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
isMulticastCapable() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
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
 
isNotificationAllowed(FlagAffectedCommand, List<AbstractListenerImpl.ListenerInvocation>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
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.ClusteredRepeatableReadEntry
 
isNull() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isNull() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isNull() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
isNull() - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is null.
isOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
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(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isOnePhaseTotalOrderCommit(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
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
 
ISPNEagerTopDocs - Class in org.infinispan.query.clustered
ISPNEagerTopDocs.
ISPNEagerTopDocs(TopDocs, Object[]) - Constructor for class org.infinispan.query.clustered.ISPNEagerTopDocs
 
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
 
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
 
isProperWriter(InvocationContext, FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
isProperWriter(InvocationContext, FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
isPutIfAbsent() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isQuiescent() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns true if all worker threads are currently idle.
isQuitting() - Method in interface org.infinispan.cli.Context
 
isQuitting() - Method in class org.infinispan.cli.impl.ContextImpl
 
isReadOnly() - Method in class org.infinispan.transaction.LocalTransaction
 
isReady() - Method in interface org.infinispan.util.concurrent.BlockingRunnable
 
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
 
isReducePhaseDistributed() - Method in class org.infinispan.commands.read.MapCombineCommand
 
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.commons.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.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.configuration.cache.CacheMode
 
isReturnEntry() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
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.commands.write.RemoveCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.ReplaceCommand
 
isReturnValueExpected() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
isReturnValueExpected() - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
isRollbackReceived() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
check if the transaction is marked for rollback (by the Rollback Command)
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(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isShutdown() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns true if this pool has been shut down.
isShutdown - Variable in class org.infinispan.distexec.DefaultExecutorService
 
isShutdown() - Method in class org.infinispan.distexec.DefaultExecutorService
 
isShutdown() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
isShutdown() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
isShutdown() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
isShutdown() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
isShutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isStarted() - Method in interface org.infinispan.affinity.KeyAffinityService
Checks weather or not the service is started.
isStarted() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
isStarted() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
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.query.impl.InfinispanQueryStatisticsInfo
 
isStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
isStopped() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.TaskContext
Verifies if the the TaskContext is marked as stopped.
isStopped() - Method in class org.infinispan.persistence.TaskContextImpl
 
isStopping() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
isStoreEnabled() - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
isStoreEnabled(FlagAffectedCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
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.lucene.LuceneKey2StringMapper
 
isSupportedType(Class<?>) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
isSupportedType(Class<?>) - Method in interface org.infinispan.persistence.keymappers.Key2StringMapper
Do we support this key type?
isSupportedType(Class<?>) - Method in class org.infinispan.persistence.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.interceptors.base.BaseRpcInterceptor
 
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
 
isTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
isTcpNoDelay() - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
isTerminated() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class org.infinispan.distexec.DefaultExecutorService
 
isTerminated() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
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.BlockingTaskAwareExecutorServiceImpl
 
isTerminated() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
isTerminating() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Returns true if the process of termination has commenced but not yet completed.
isTimeExpired(long) - Method in class org.infinispan.util.DefaultTimeService
 
isTimeExpired(long) - Method in interface org.infinispan.util.TimeService
 
isTotalOrder() - Method in class org.infinispan.topology.CacheJoinInfo
 
isTotalOrder() - Method in class org.infinispan.topology.ClusterCacheStatus
 
isTotalOrder() - Method in enum org.infinispan.transaction.TransactionProtocol
 
isTransactional() - Method in enum org.infinispan.transaction.TransactionMode
 
isTransactionCompleted(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
isTransactionInProgress() - Method in class org.infinispan.query.backend.TransactionalEventTransactionContext
Returns a boolean value whether or not a transaction is in progress (JTA transaction and in this case *not* an org.hibernate transaction).
isTransactionManagerExpected() - Method in class org.infinispan.query.backend.SearchableCacheConfiguration
 
isTransactionPrepared(GlobalTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Checks both internal state and transaction table's state for the given tx.
isTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
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.core.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
 
isUpdated() - Method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
 
isUseSetter() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isUseXaXid() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
isValid() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
isValid() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isValid() - Method in interface org.infinispan.container.entries.CacheEntry
 
isValid() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
isValid() - Method in class org.infinispan.container.entries.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
 
isValueAvailableLocally(ConsistentHash, Object) - Method in class org.infinispan.interceptors.ClusteringInterceptor
 
isVariableLimitSupported() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
isVersioningEnabled(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isWritable() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isWrite() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
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.commons.equivalence.EquivalentHashMap.EntrySet
 
iterator() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
 
iterator() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Returns an iterator over the elements in this set.
iterator() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
 
iterator() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
iterator() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
iterator() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
iterator() - Method in class org.infinispan.commons.util.ForwardingList
 
iterator() - Method in class org.infinispan.commons.util.ImmutableListCopy
 
iterator() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList
 
iterator() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet
 
iterator() - Method in class org.infinispan.container.DefaultDataContainer
 
iterator(FetchOptions) - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a ResultIterator.
iterator() - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a ResultIterator.
iterator(FetchOptions) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
iterator(FetchOptions) - Method in interface org.infinispan.query.dsl.embedded.LuceneQuery
Returns the results of a search as a ResultIterator.
iterator() - Method in interface org.infinispan.query.dsl.embedded.LuceneQuery
Returns the results of a search as a ResultIterator.
iterator() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
iterator(FetchOptions) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
iterator() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
iterator() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 

J

JavaSerializationMarshaller - Class in org.infinispan.commons.marshall
Standard Java serialization marshaller.
JavaSerializationMarshaller() - Constructor for class org.infinispan.commons.marshall.JavaSerializationMarshaller
 
JBossExternalizerAdapter - Class in org.infinispan.commons.marshall.jboss
 
JBossExternalizerAdapter(Externalizer<?>) - Constructor for class org.infinispan.commons.marshall.jboss.JBossExternalizerAdapter
 
JBossMarshaller - Class in org.infinispan.marshall.core
A JBoss Marshalling based marshaller that is oriented at internal, embedded, Infinispan usage.
JBossMarshaller() - Constructor for class org.infinispan.marshall.core.JBossMarshaller
 
JBossMarshaller(ExternalizerTable, Configuration, InvocationContextContainer, GlobalConfiguration) - Constructor for class org.infinispan.marshall.core.JBossMarshaller
 
JBossMarshaller.EmbeddedContextClassResolver - Class in org.infinispan.marshall.core
An embedded context class resolver that is able to retrieve a class loader from the embedded Infinispan call context.
JBossMarshallerFactory - Class in org.infinispan.commons.marshall.jboss
A JBoss Marshalling factory class for retrieving marshaller/unmarshaller instances.
JBossMarshallerFactory() - Constructor for class org.infinispan.commons.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
 
JdbcBinaryStore - Class in org.infinispan.persistence.jdbc.binary
AdvancedLoadWriteStore implementation that will store all the buckets as rows in database, each row corresponding to a bucket.
JdbcBinaryStore() - Constructor for class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
JdbcBinaryStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
JdbcBinaryStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, ConnectionFactoryConfiguration, boolean, TableManipulationConfiguration, int, long) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfiguration
 
JdbcBinaryStoreConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
 
JdbcBinaryStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
JdbcBinaryStoreConfigurationBuilder.BinaryTableManipulationConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
 
JdbcMixedStore - Class in org.infinispan.persistence.jdbc.mixed
Cache store that combines functionality of JdbcBinaryStore and JdbcStringBasedStore.
JdbcMixedStore() - Constructor for class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
JdbcMixedStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
JdbcMixedStoreConfiguration.
JdbcMixedStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, ConnectionFactoryConfiguration, boolean, int, int, DatabaseType, TableManipulationConfiguration, TableManipulationConfiguration, String, int, long) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
JdbcMixedStoreConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
JdbcMixedCacheStoreConfigurationBuilder.
JdbcMixedStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
 
JdbcMixedStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Interface in org.infinispan.persistence.jdbc.configuration
 
JdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Interface in org.infinispan.persistence.jdbc.configuration
JdbcStoreConfigurationChildBuilder.
JdbcStoreConfigurationParser60 - Class in org.infinispan.persistence.jdbc.configuration
JdbcStoreConfigurationParser60.
JdbcStoreConfigurationParser60() - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
 
JdbcStringBasedStore - Class in org.infinispan.persistence.jdbc.stringbased
AdvancedCacheLoader implementation that stores the entries in a database.
JdbcStringBasedStore() - Constructor for class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
JdbcStringBasedStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
JdbcStringBasedStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, ConnectionFactoryConfiguration, boolean, String, TableManipulationConfiguration) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
JdbcStringBasedStoreConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
JdbcStringBasedStoreConfigurationBuilder.
JdbcStringBasedStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
 
JdbcUtil - Class in org.infinispan.persistence.jdbc
Contains common methods used by JDBC CacheStores.
JdbcUtil() - Constructor for class org.infinispan.persistence.jdbc.JdbcUtil
 
JDK_SETS - Static variable in interface org.infinispan.marshall.core.Ids
 
JGROUPS_ADDRESS - Static variable in interface org.infinispan.marshall.core.Ids
 
JGROUPS_TOPOLOGY_AWARE_ADDRESS - Static variable in interface org.infinispan.marshall.core.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
 
JGroupsBackupResponse - Class in org.infinispan.remoting.transport.jgroups
 
JGroupsBackupResponse(Map<XSiteBackup, Future<Object>>, TimeService) - 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
 
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
 
JMXConnection - Class in org.infinispan.cli.connection.jmx
 
JMXConnection(JMXUrl) - Constructor for class org.infinispan.cli.connection.jmx.JMXConnection
 
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
 
JMXRemotingConnector - Class in org.infinispan.cli.connection.jmx.remoting
 
JMXRemotingConnector() - Constructor for class org.infinispan.cli.connection.jmx.remoting.JMXRemotingConnector
 
JMXRemotingUrl - Class in org.infinispan.cli.connection.jmx.remoting
 
JMXRemotingUrl(String) - Constructor for class org.infinispan.cli.connection.jmx.remoting.JMXRemotingUrl
 
JMXRMIConnector - Class in org.infinispan.cli.connection.jmx.rmi
 
JMXRMIConnector() - Constructor for class org.infinispan.cli.connection.jmx.rmi.JMXRMIConnector
 
JMXRMIUrl - Class in org.infinispan.cli.connection.jmx.rmi
 
JMXRMIUrl(String) - Constructor for class org.infinispan.cli.connection.jmx.rmi.JMXRMIUrl
 
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
 
JMXUrl - Interface in org.infinispan.cli.connection.jmx
 
JmxUtil - Class in org.infinispan.jmx
Class containing JMX related utility methods.
JmxUtil() - Constructor for class org.infinispan.jmx.JmxUtil
 
jndiUrl() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
 
jndiUrl(String) - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
 
join() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Returns the result of the computation when it is done.
join(List<String>, String) - Static method in class org.infinispan.commons.util.Util
 
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(String, CacheJoinInfo, CacheTopologyHandler) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
joinRehashAborted(Address, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
joinRehashAborted(Address, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
joinRehashAborted(Address, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
joinRehashAborted(Address, String) - Method in class org.infinispan.query.logging.Log_$logger
 
joinRehashAborted(Address, String) - Method in interface org.infinispan.util.logging.Log
 
joinRehashAborted(Address, String) - Method in class org.infinispan.util.logging.Log_$logger
 
joinRehashAborted$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
joinRehashAborted$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
joinRehashAborted$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
joinRehashAborted$str() - Method in class org.infinispan.query.logging.Log_$logger
 
joinRehashAborted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
joinRehashCompleted(Address, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
joinRehashCompleted(Address, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
joinRehashCompleted(Address, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
joinRehashCompleted(Address, String) - Method in class org.infinispan.query.logging.Log_$logger
 
joinRehashCompleted(Address, String) - Method in interface org.infinispan.util.logging.Log
 
joinRehashCompleted(Address, String) - Method in class org.infinispan.util.logging.Log_$logger
 
joinRehashCompleted$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
joinRehashCompleted$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
joinRehashCompleted$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
joinRehashCompleted$str() - Method in class org.infinispan.query.logging.Log_$logger
 
joinRehashCompleted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
JPAQueryGenerator - Class in org.infinispan.query.dsl.impl
Generates a JPA query to satisfy the condition created with the builder.
JPAQueryGenerator() - Constructor for class org.infinispan.query.dsl.impl.JPAQueryGenerator
 

K

key - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
key - Variable in class org.infinispan.commands.read.AbstractDataCommand
 
key - Variable in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
key - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
key - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
KEY - Static variable in interface org.infinispan.query.ProjectionConstants
 
key - Variable in class org.infinispan.registry.ScopedKey
 
key2StringMapper() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
key2StringMapper(String) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
The class name of a Key2StringMapper to use for mapping keys to strings suitable for storage in a database table.
key2StringMapper(Class<? extends Key2StringMapper>) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
The class of a Key2StringMapper to use for mapping keys to strings suitable for storage in a database table.
key2StringMapper(String) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
key2StringMapper(Class<? extends Key2StringMapper>) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
key2StringMapper(String) - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationChildBuilder
The class name of a Key2StringMapper to use for mapping keys to strings suitable for storage in a database table.
key2StringMapper(Class<? extends Key2StringMapper>) - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationChildBuilder
The class of a Key2StringMapper to use for mapping keys to strings suitable for storage in a database table.
key2StringMapper() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
key2StringMapper(String) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
The class name of a Key2StringMapper to use for mapping keys to strings suitable for storage in a database table.
key2StringMapper(Class<? extends Key2StringMapper>) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
The class of a Key2StringMapper to use for mapping keys to strings suitable for storage in a database table.
Key2StringMapper - Interface in org.infinispan.persistence.keymappers
Defines the logic of mapping a key object to a String.
KEY_DOES_NOT_EXIST_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
KEY_SIZE_ESTIMATE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
KEY_STORE_FILE_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
KEY_STORE_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
KEY_VALUE_PAIR_ID - Static variable in interface org.infinispan.marshall.core.Ids
 
keyAffected() - Method in class org.infinispan.atomic.ClearOperation
 
keyAffected() - Method in class org.infinispan.atomic.Operation
 
keyAffected() - Method in class org.infinispan.atomic.PutOperation
 
keyAffected() - Method in class org.infinispan.atomic.RemoveOperation
 
KeyAffinityService<K> - Interface in org.infinispan.affinity
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
KeyAffinityServiceFactory - Class in org.infinispan.affinity
Factory for KeyAffinityService.
KeyAffinityServiceFactory() - Constructor for class org.infinispan.affinity.KeyAffinityServiceFactory
 
KeyAffinityServiceImpl<K> - Class in org.infinispan.affinity
Implementation of KeyAffinityService.
KeyAffinityServiceImpl(Executor, Cache<? extends K, ?>, KeyGenerator<? extends K>, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.KeyAffinityServiceImpl
 
keyClassNotFound(String, Exception) - Method in interface org.infinispan.query.logging.Log
 
keyClassNotFound(String, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
keyClassNotFound$str() - Method in class org.infinispan.query.logging.Log_$logger
 
keyDoesNotMapToLocalNode(Object, Collection) - Method in class org.infinispan.lucene.logging.Log_$logger
 
keyDoesNotMapToLocalNode(Object, Collection) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
keyDoesNotMapToLocalNode(Object, Collection) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
keyDoesNotMapToLocalNode(Object, Collection) - Method in class org.infinispan.query.logging.Log_$logger
 
keyDoesNotMapToLocalNode(Object, Collection<Address>) - Method in interface org.infinispan.util.logging.Log
 
keyDoesNotMapToLocalNode(Object, Collection) - Method in class org.infinispan.util.logging.Log_$logger
 
keyDoesNotMapToLocalNode$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
keyDoesNotMapToLocalNode$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
keyDoesNotMapToLocalNode$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
keyDoesNotMapToLocalNode$str() - Method in class org.infinispan.query.logging.Log_$logger
 
keyDoesNotMapToLocalNode$str() - Method in class org.infinispan.util.logging.Log_$logger
 
keyEq - Variable in class org.infinispan.context.AbstractInvocationContextFactory
 
keyEquivalence() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
 
keyEquivalence(Equivalence<K>) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Set the Equivalence instance to use to compare keys stored in data container.
keyEquivalence - Variable in class org.infinispan.transaction.AbstractCacheTransaction
Equivalence function to compare keys that are stored in temporary collections used in the cache transaction to keep track of locked keys, looked up keys...etc.
KeyFilter - Interface in org.infinispan.notifications
A filter for keys.
KeyGenerator<K> - Interface in org.infinispan.affinity
Used for generating keys; used by KeyAffinityService to generate the affinity keys.
keyMappperUnexpectedStringFormat(String) - Method in interface org.infinispan.lucene.logging.Log
 
keyMappperUnexpectedStringFormat(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
keyMappperUnexpectedStringFormat$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
keyMigrationFailed(String, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
keyMigrationFailed(String, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
keyMigrationFailed(String, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
keyMigrationFailed(String, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
keyMigrationFailed(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
keyMigrationFailed(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
keyMigrationFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
keyMigrationFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
keyMigrationFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
keyMigrationFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
keyMigrationFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns an enumeration of the keys in this table.
keys - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
keys - Variable in class org.infinispan.query.clustered.ISPNEagerTopDocs
 
keys(S) - Method in interface org.infinispan.registry.ClusterRegistry
 
keys(S) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
keys() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
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 and cache loader.
keySet() - Method in class org.infinispan.CacheImpl
 
keySet() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
keySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns all keys in the remote server.
keySet() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
keySet - Variable in class org.infinispan.commons.util.AbstractMap
 
keySet() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a Set view of the keys contained in this map.
keySet(V) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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.commons.util.FastCopyHashMap
 
KeySet() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
keySet() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
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() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Set view of the keys contained in this map.
KeySetCommand - Class in org.infinispan.commands.read
Command implementation for Map.keySet() functionality.
KeySetCommand(DataContainer, Set<Flag>) - Constructor for class org.infinispan.commands.read.KeySetCommand
 
KeySetCommand.ExpiredFilteredKeySet - Class in org.infinispan.commands.read
 
keySizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
keySizeEstimate() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
keySizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
keySizeEstimate(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
This hint allows sizing of byte buffers when serializing and deserializing keys, to minimize array resizing.
keySizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
keySizeEstimate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
keySizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
keySizeEstimate(int) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
The class name of the driver used for connecting to the database.
keysToExecutionNodes(DistributedTaskExecutionPolicy, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
 
keyStoreFileName() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
keyStoreFileName(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Specifies the filename of a keystore to use to create the SSLContext You also need to specify a SslConfigurationBuilder.keyStorePassword(char[]).
keyStorePassword() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
keyStorePassword(char[]) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Specifies the password needed to open the keystore You also need to specify a SslConfigurationBuilder.keyStoreFileName(String) Alternatively specify an array of #keyManagers(KeyManager[])
KeysValidateFilter - Class in org.infinispan.remoting.responses
Used in Total Order based commit protocol in Distributed Mode

This filter awaits for one valid response for each key to be validated.

KeysValidateFilter(Address, Set<Object>) - Constructor for class org.infinispan.remoting.responses.KeysValidateFilter
 
keyToString(Object) - Method in class org.infinispan.query.backend.KeyTransformationHandler
 
KeyTransformationHandler - Class in org.infinispan.query.backend
This transforms arbitrary keys to a String which can be used by Lucene as a document identifier, and vice versa.
KeyTransformationHandler() - Constructor for class org.infinispan.query.backend.KeyTransformationHandler
 
keyTransformationHandler - Variable in class org.infinispan.query.impl.CacheQueryImpl
 
KeyValuePair<K,V> - Class in org.infinispan.util
Holds logically related key-value pairs or binary tuples.
KeyValuePair(K, V) - Constructor for class org.infinispan.util.KeyValuePair
 
KeyValuePair.Externalizer - Class in org.infinispan.util
 
KeyVisitor<T> - Interface in org.infinispan.lucene
All objects being used as keys to store entries by the Lucene Directory implement IndexScopedKey which enforces visitability with a KeyVisitor.
kill(UUID) - Method in class org.infinispan.query.clustered.QueryBox
Kill the query (DocumentExtractor)
KnownComponentNames - Class in org.infinispan.factories
Holder for known named component names.
KnownComponentNames() - Constructor for class org.infinispan.factories.KnownComponentNames
 

L

l1() - 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.
L1LastChanceInterceptor - Class in org.infinispan.interceptors.distribution
L1 based interceptor that flushes the L1 cache at the end after a transaction/entry is committed to the data container but before the lock has been released.
L1LastChanceInterceptor() - Constructor for class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
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.
l1Manager - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
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
 
L1TxInterceptor - Class in org.infinispan.interceptors.distribution
Interceptor that handles L1 logic for transactional caches.
L1TxInterceptor() - Constructor for class org.infinispan.interceptors.distribution.L1TxInterceptor
 
L1WriteSynchronizer - Class in org.infinispan.interceptors.distribution
A write synchronizer that allows for a single thread to run the L1 update while others can block until it is completed.
L1WriteSynchronizer(DataContainer, long, StateTransferLock, ClusteringDependentLogic) - Constructor for class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
last() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
lastIndexOf(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
lastIndexOf(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
lastModified() - Method in class org.infinispan.io.GridFile
 
lastUsed - Variable in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
lastUsed - Variable in class org.infinispan.container.entries.TransientCacheEntry
 
lastUsed - Variable in class org.infinispan.container.entries.TransientCacheValue
 
lastUsed - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
lastUsed - Variable in class org.infinispan.container.entries.TransientMortalCacheValue
 
lastUsed() - Method in interface org.infinispan.metadata.InternalMetadata
 
lastUsed() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
lazyDeserializationDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
lazyDeserializationDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
lazyDeserializationDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
lazyDeserializationDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
lazyDeserializationDeprecated() - Method in interface org.infinispan.util.logging.Log
 
lazyDeserializationDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
lazyDeserializationDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
lazyDeserializationDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
lazyDeserializationDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
lazyDeserializationDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
lazyDeserializationDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
LazyInitializingBlockingTaskAwareExecutorService - Class in org.infinispan.executors
A delegating executor that lazily constructs and initializes the underlying executor.
LazyInitializingBlockingTaskAwareExecutorService(ExecutorFactory, Properties, TimeService) - Constructor for class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
LazyInitializingExecutorService - Class in org.infinispan.executors
A delegating executor that lazily constructs and initializes the underlying executor, since unused JDK executors are expensive.
LazyInitializingExecutorService(ExecutorFactory, Properties) - Constructor for class org.infinispan.executors.LazyInitializingExecutorService
 
LazyInitializingScheduledExecutorService - Class in org.infinispan.executors
A delegating scheduled executor that lazily constructs and initalizes the underlying scheduled executor, since unused JDK executors are expensive.
LazyInitializingScheduledExecutorService(ScheduledExecutorFactory, Properties) - Constructor for class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
LazyIterator - Class in org.infinispan.query.impl
Implementation for ResultIterator.
LazyIterator(DocumentExtractor, QueryResultLoader, int) - Constructor for class org.infinispan.query.impl.LazyIterator
 
lazyQueryId - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
leave(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Forwards the leave request to the coordinator.
leave(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
leave(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
LegacyAdvancedExternalizerAdapter<T> - Class in org.infinispan.marshall
Deprecated.
Convert your externalizers to AdvancedExternalizer
LegacyAdvancedExternalizerAdapter(AdvancedExternalizer<T>) - Constructor for class org.infinispan.marshall.LegacyAdvancedExternalizerAdapter
Deprecated.
 
LegacyBufferSizePredictorAdapter - Class in org.infinispan.marshall
Deprecated.
LegacyBufferSizePredictorAdapter(BufferSizePredictor) - Constructor for class org.infinispan.marshall.LegacyBufferSizePredictorAdapter
Deprecated.
 
LegacyExternalizerAdapter<T> - Class in org.infinispan.marshall
Deprecated.
LegacyExternalizerAdapter(Externalizer<T>) - Constructor for class org.infinispan.marshall.LegacyExternalizerAdapter
Deprecated.
 
LegacyKeySupportSystemProperties - Class in org.infinispan.commons.util
A wrapper around system properties that supports legacy keys
LegacyKeySupportSystemProperties() - Constructor for class org.infinispan.commons.util.LegacyKeySupportSystemProperties
 
LegacyMarshallerAdapter - Class in org.infinispan.marshall
Deprecated.
LegacyMarshallerAdapter(Marshaller) - Constructor for class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
LegacyNotifyingFutureAdaptor<T> - Class in org.infinispan.util.concurrent
Deprecated.
LegacyNotifyingFutureAdaptor() - Constructor for class org.infinispan.util.concurrent.LegacyNotifyingFutureAdaptor
Deprecated.
 
LegacyStreamingMarshallerAdapter - Class in org.infinispan.marshall
Deprecated.
LegacyStreamingMarshallerAdapter(StreamingMarshaller) - Constructor for class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
length() - Method in class org.infinispan.io.GridFile
 
length() - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
length() - Method in class org.infinispan.lucene.impl.SingleChunkIndexInput
 
Lifecycle - Interface in org.infinispan.commons.api
Lifecycle interface that defines the lifecycle of components
Lifecycle - Interface in org.infinispan.lifecycle
Lifecycle interface that defines the lifecycle of components
LifecycleCallbacks - Class in org.infinispan.lucene
Module lifecycle callbacks implementation that enables module specific AdvancedExternalizer implementations to be registered.
LifecycleCallbacks() - Constructor for class org.infinispan.lucene.LifecycleCallbacks
 
LifecycleManager - Class in org.infinispan.query.impl
Lifecycle of the Query module: initializes the Hibernate Search engine and shuts it down at cache stop.
LifecycleManager() - Constructor for class org.infinispan.query.impl.LifecycleManager
 
lifespan - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
lifespan() - 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.MortalCacheEntry
 
lifespan - Variable in class org.infinispan.container.entries.MortalCacheValue
 
lifespan - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
lifespan - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
lifespan(long, TimeUnit) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
lifespan(long) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
lifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
lifespan() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
lifespan(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
Set lifespan time with a given time unit.
lifespan(long) - Method in interface org.infinispan.metadata.Metadata.Builder
Set lifespan time assuming that the time unit is milliseconds.
lifespan() - Method in interface org.infinispan.metadata.Metadata
Returns the lifespan of the cache entry with which this metadata object is associated, in milliseconds.
lifespanUnit - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
lifo() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
lifo(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Sets the LIFO status.
like(String) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument (which is expected to be a String) matches a wildcard pattern that follows the JPA rules.
LINKED_LIST - Static variable in interface org.infinispan.marshall.core.Ids
 
list() - Method in class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
list() - Method in class org.infinispan.io.GridFile
 
list(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
list() - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
list() - Method in interface org.infinispan.query.CacheQuery
Returns the results of a search as a list.
list() - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
list() - Method in interface org.infinispan.query.dsl.Query
Returns the results of a search as a list.
list() - Method in class org.infinispan.query.impl.CacheQueryImpl
 
LIST_ARRAY - Static variable in interface org.infinispan.marshall.core.Ids
 
listAll() - Method in class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
listAll() - Method in class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
listAll() - Method in interface org.infinispan.lucene.cacheloader.InternalDirectoryContract
 
listAll() - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
new name for list() in Lucene 3.0
ListArray() - Constructor for class org.infinispan.marshall.exts.ArrayExternalizers.ListArray
 
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.
ListenerInvocation(Object, Method, boolean, boolean, KeyFilter, ClassLoader) - Constructor for class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
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
 
ListExternalizer - Class in org.infinispan.marshall.exts
List externalizer dealing with ArrayList and LinkedList implementations.
ListExternalizer() - Constructor for class org.infinispan.marshall.exts.ListExternalizer
 
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.commons.util.ForwardingList
 
listIterator(int) - Method in class org.infinispan.commons.util.ForwardingList
 
listIterator() - Method in class org.infinispan.commons.util.ImmutableListCopy
 
listIterator(int) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
load() - Method in interface org.infinispan.cli.Config
 
load() - Method in class org.infinispan.cli.shell.ConfigImpl
 
load(Class<S>, ClassLoader...) - Static method in class org.infinispan.commons.util.ServiceFinder
 
load(Object) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
 
load(Object) - Method in class org.infinispan.persistence.async.AsyncCacheLoader
 
load(K) - Method in class org.infinispan.persistence.cli.CLInterfaceLoader
 
load(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
load(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
 
load(Object) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
load(Object) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
load(Object) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
load(Object) - Method in class org.infinispan.persistence.remote.RemoteStore
 
load(K) - Method in interface org.infinispan.persistence.spi.CacheLoader
Fetches an entry from the storage.
load(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
load(EntityInfo) - Method in class org.infinispan.query.impl.EntityLoader
 
load(Collection<EntityInfo>) - Method in class org.infinispan.query.impl.EntityLoader
 
load(Collection<EntityInfo>) - Method in class org.infinispan.query.impl.ProjectionLoader
 
load(EntityInfo) - Method in class org.infinispan.query.impl.ProjectionLoader
 
load(EntityInfo) - Method in interface org.infinispan.query.impl.QueryResultLoader
 
load(Collection<EntityInfo>) - Method in interface org.infinispan.query.impl.QueryResultLoader
 
LOAD_ALL_FILTER - Static variable in interface org.infinispan.persistence.spi.AdvancedCacheLoader.KeyFilter
 
loadBucket(Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
loadClass(String, ClassLoader) - Static method in class org.infinispan.commons.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.commons.util.Util
Loads the specified class using the passed classloader, or, if it is null the Infinispan classes' classloader.
loadEntityInfo(int) - Method in class org.infinispan.query.impl.AbstractIterator
 
loadEntityInfo(int) - Method in class org.infinispan.query.impl.EagerIterator
 
loadEntityInfo(int) - Method in class org.infinispan.query.impl.LazyIterator
 
LoaderConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in class org.infinispan.query.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in interface org.infinispan.util.logging.Log
 
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in class org.infinispan.util.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass$str() - Method in class org.infinispan.query.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
loadFromAllStores(Object, InvocationContext) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
loadFromAllStores(Object, InvocationContext) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
loadIfNeeded(InvocationContext, Object, boolean, FlagAffectedCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
loadIfNeeded(InvocationContext, Object, boolean, FlagAffectedCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
Loads from the cache loader the entry for the given key.
loadModuleCommandHandlers(ClassLoader) - Method in class org.infinispan.util.ModuleProperties
 
LOCAL_MODE_ADDRESS - Static variable in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
localAndPhysicalAddress(Address, List) - Method in class org.infinispan.lucene.logging.Log_$logger
 
localAndPhysicalAddress(Address, List) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
localAndPhysicalAddress(Address, List) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
localAndPhysicalAddress(Address, List) - Method in class org.infinispan.query.logging.Log_$logger
 
localAndPhysicalAddress(Address, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
localAndPhysicalAddress(Address, List) - Method in class org.infinispan.util.logging.Log_$logger
 
localAndPhysicalAddress$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
localAndPhysicalAddress$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
localAndPhysicalAddress$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
localAndPhysicalAddress$str() - Method in class org.infinispan.query.logging.Log_$logger
 
localAndPhysicalAddress$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 class org.infinispan.lucene.logging.Log_$logger
 
localExecutionFailed(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
localExecutionFailed(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
localExecutionFailed(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
localExecutionFailed(Throwable) - Method in interface org.infinispan.util.logging.Log
 
localExecutionFailed(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
localExecutionFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
localExecutionFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
localExecutionFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
localExecutionFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
localExecutionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
localExecutorService - Variable in class org.infinispan.distexec.DefaultExecutorService
 
LocalFlagAffectedCommand - Interface in org.infinispan.commands
Commands affected by Flags will be checked locally to control certain behaviors such whether or not to invoke certain commands remotely, check cache store etc.
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in class org.infinispan.lucene.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in class org.infinispan.query.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in interface org.infinispan.util.logging.Log
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in class org.infinispan.util.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload$str() - Method in class org.infinispan.query.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload$str() - Method in class org.infinispan.util.logging.Log_$logger
 
localLockIntention - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
LocalLockMergingSegmentReadLocker - Class in org.infinispan.lucene.readlocks
LocalLockMergingSegmentReadLocker decorates the DistributedSegmentReadLocker to minimize remote operations in case several IndexReaders are opened on the same Infinispan based Directory.
LocalLockMergingSegmentReadLocker(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Create a new LocalLockMergingSegmentReadLocker for specified cache and index name.
LocalLockMergingSegmentReadLocker(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Create a new LocalLockMergingSegmentReadLocker with special purpose caches
LocalLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
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
 
LocalOnlyCacheLoader - Interface in org.infinispan.persistence.spi
Marker interface for cache loaders that should only load values on the originating nodes.
LocalQueryInterceptor - Class in org.infinispan.query.backend

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

LocalQueryInterceptor(SearchFactoryIntegrator) - Constructor for class org.infinispan.query.backend.LocalQueryInterceptor
 
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, Equivalence<Object>) - 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(Equivalence<Object>) - 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, Equivalence<Object>) - Constructor for class org.infinispan.transaction.xa.LocalXaTransaction
 
Locate - Class in org.infinispan.cli.commands.server
 
Locate() - Constructor for class org.infinispan.cli.commands.server.Locate
 
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.SingleFileStoreConfiguration
 
location(String) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
Sets a location on disk where the store can write.
location() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
The location of the root directory of the index.
location(String) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
Path to the root directory containing all indexes.
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(Object, boolean) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Acquires internal lock to interact with DataContainer
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() - 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
lockAcquisitionTimeout() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfiguration
 
lockAcquisitionTimeout(long) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
lockAcquisitionTimeout() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
lockAcquisitionTimeout(long) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
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.
lockAndWrap(InvocationContext, Object, InternalCacheEntry, FlagAffectedCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
lockAndWrap(InvocationContext, Object, InternalCacheEntry, FlagAffectedCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
 
lockAndWrap(InvocationContext, Object, InternalCacheEntry, FlagAffectedCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
lockBucketForReading(Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
Acquires read lock on the given key.
lockBucketForWriting(Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
Acquires write lock on the given key.
lockConcurrencyLevel() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfiguration
 
lockConcurrencyLevel() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
lockConcurrencyLevel(int) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
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.
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() - 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, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
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 - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
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
 
Log - Interface in org.infinispan.client.hotrod.logging
Log abstraction for the hot rod client.
Log - Interface in org.infinispan.commons.logging
Infinispan's log abstraction layer on top of JBoss Logging.
log - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
Log - Interface in org.infinispan.lucene.logging
Log abstraction for the lucene directory.
Log - Interface in org.infinispan.persistence.jdbc.logging
Log abstraction for the JDBC cache store.
Log - Interface in org.infinispan.persistence.remote.logging
Log abstraction for the remote cache store.
Log - Interface in org.infinispan.query.logging
Log abstraction for the query module.
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.
Log_$logger - Class in org.infinispan.client.hotrod.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.client.hotrod.logging.Log_$logger
 
Log_$logger - Class in org.infinispan.commons.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.commons.logging.Log_$logger
 
Log_$logger - Class in org.infinispan.lucene.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.lucene.logging.Log_$logger
 
Log_$logger - Class in org.infinispan.persistence.jdbc.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.persistence.jdbc.logging.Log_$logger
 
Log_$logger - Class in org.infinispan.persistence.remote.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.persistence.remote.logging.Log_$logger
 
Log_$logger - Class in org.infinispan.query.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.query.logging.Log_$logger
 
Log_$logger - Class in org.infinispan.util.logging
Warning this class consists of generated code.
Log_$logger(Logger) - Constructor for class org.infinispan.util.logging.Log_$logger
 
logErrorAndThrowExceptionIfNeeded(int, HotRodClientException) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
LogFactory - Class in org.infinispan.client.hotrod.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.client.hotrod.logging.LogFactory
 
LogFactory - Class in org.infinispan.commons.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.commons.logging.LogFactory
 
LogFactory - Class in org.infinispan.util.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.util.logging.LogFactory
 
logFlushTimeoutDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
logFlushTimeoutDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
logFlushTimeoutDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
logFlushTimeoutDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
logFlushTimeoutDeprecated() - Method in interface org.infinispan.util.logging.Log
 
logFlushTimeoutDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
logFlushTimeoutDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
logFlushTimeoutDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
logFlushTimeoutDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
logFlushTimeoutDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
logFlushTimeoutDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
logRoutingTableInformation() - Method in class org.infinispan.topology.CacheTopology
 
LONG - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
LongAdder - Class in org.infinispan.commons.util.concurrent.jdk8backported
One or more variables that together maintain an initially zero long sum.
LongAdder() - Constructor for class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Creates a new adder with initial sum of zero.
longValue() - Method in class org.infinispan.commons.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
 
lookedUpEntriesTopology() - Method in class org.infinispan.transaction.RemoteTransaction
 
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.commons.util.AbstractFileLookup
Looks up the file, see : FileLookupFactory.DefaultFileLookup.
lookupFile(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
Looks up the file, see : FileLookupFactory.DefaultFileLookup.
lookupFile(String, ClassLoader) - Method in class org.infinispan.util.FileLookup
Deprecated.
 
lookupFileLocation(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
lookupFileLocation(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
 
lookupFileLocations(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
lookupFileLocations(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
 
lookupFileStrict(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
Looks up the file, see : FileLookupFactory.DefaultFileLookup.
lookupFileStrict(URI, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
lookupFileStrict(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
Looks up the file, see : FileLookupFactory.DefaultFileLookup.
lookupFileStrict(URI, ClassLoader) - Method in interface org.infinispan.commons.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.
lt(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is less than the given value.
lte(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is less than or equal to the given value.
LuceneCacheLoader - Class in org.infinispan.lucene.cacheloader
A CacheLoader meant to load Lucene index(es) from filesystem based Lucene index(es).
LuceneCacheLoader() - Constructor for class org.infinispan.lucene.cacheloader.LuceneCacheLoader
 
LuceneKey2StringMapper - Class in org.infinispan.lucene
To configure a JdbcStringBasedCacheStoreConfig for the Lucene Directory, use this Key2StringMapper implementation.
LuceneKey2StringMapper() - Constructor for class org.infinispan.lucene.LuceneKey2StringMapper
 
LuceneLoaderConfiguration - Class in org.infinispan.lucene.cacheloader.configuration
Configuration bean for the LuceneCacheLoader.
LuceneLoaderConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, int, String) - Constructor for class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
 
LuceneLoaderConfigurationBuilder - Class in org.infinispan.lucene.cacheloader.configuration
LuceneLoaderConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
 
LuceneQuery - Interface in org.infinispan.query.dsl.embedded
A Query kind that offers iteration and lazy/eager loading options.
luceneStorageAsBinaryEnabled(String, String) - Method in interface org.infinispan.lucene.logging.Log
 
luceneStorageAsBinaryEnabled(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageAsBinaryEnabled$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageHavingIdleTimeSet(String, String) - Method in interface org.infinispan.lucene.logging.Log
 
luceneStorageHavingIdleTimeSet(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageHavingIdleTimeSet$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageHavingLifespanSet(String, String) - Method in interface org.infinispan.lucene.logging.Log
 
luceneStorageHavingLifespanSet(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageHavingLifespanSet$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageNoStateTransferEnabled(String, String) - Method in interface org.infinispan.lucene.logging.Log
 
luceneStorageNoStateTransferEnabled(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
luceneStorageNoStateTransferEnabled$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
LuceneVersionDetector - Class in org.infinispan.lucene.impl
Since Lucene requires extension of Directory (it's not an interface) we need to apply some tricks to provide the correct Directory implementation depending on the Lucene version detected on the classpath.
LuceneWorkTransformationVisitor - Class in org.infinispan.query.indexmanager
The serialized form of LuceneWork needs to be adjusted after deserialization to apply our custom keyTransformers.

M

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 - Class in org.infinispan.cli
The CLI Shell
Main() - Constructor for class org.infinispan.cli.Main
 
main(String[]) - Static method in class org.infinispan.cli.Main
The
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.commons.util.CollectionFactory
 
makeConcurrentMap(int) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeConcurrentMap(int, int) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeConcurrentMap(int, float, int) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeConcurrentMap(Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeConcurrentMap(int, Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeConcurrentMap(int, int, Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeConcurrentMap(int, float, int, Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeLinkedMap(int, float, EquivalentLinkedHashMap.IterationOrder, Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeLock(String) - Method in class org.infinispan.lucene.locking.BaseLockFactory
makeLock(String) - Method in class org.infinispan.lucene.locking.TransactionalLockFactory
makeMap(Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeMap(int, Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeMap(Map<? extends K, ? extends V>, Equivalence<K>, Equivalence<V>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeObject(SocketAddress) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
makeSet(Equivalence<T>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeSet(int, Equivalence<T>) - Static method in class org.infinispan.commons.util.CollectionFactory
 
makeSet(T...) - Static method in class org.infinispan.commons.util.CollectionFactory
Create a Set backed by the specified array.
Man2Ansi - Class in org.infinispan.cli.shell
A very simple and incomplete converter from troff-style man macro syntax to ansi
Man2Ansi(int) - Constructor for class org.infinispan.cli.shell.Man2Ansi
 
MAN_MACRO_REGEX - Static variable in class org.infinispan.cli.shell.Man2Ansi
 
ManageableComponentMetadata - Class in org.infinispan.factories.components
A specialization of ComponentMetadata, this version also includes JMX related metadata, as expressed by MBean, ManagedAttribute and ManagedOperation annotations.
ManageableComponentMetadata(Class<?>, List<Method>, List<Method>, List<Method>, boolean, boolean, List<Field>, List<Method>, List<Method>, MBean) - Constructor for class org.infinispan.factories.components.ManageableComponentMetadata
 
manageConnectionFactory() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
 
manageConnectionFactory - Variable in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
manageConnectionFactory(boolean) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
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.commons.util.concurrent.jdk8backported.ForkJoinPool
Blocks in accord with the given blocker.
ManagedConnectionFactory - Class in org.infinispan.persistence.jdbc.connectionfactory
Connection factory that can be used when on managed environments, like application servers.
ManagedConnectionFactory() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ManagedConnectionFactory
 
ManagedConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.configuration
ManagedConnectionFactoryConfiguration.
ManagedConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
ManagedConnectionFactoryConfigurationBuilder.
ManagedConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
 
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(Object, Object, Collector<Object, LuceneWork>) - Method in class org.infinispan.query.impl.massindex.IndexingMapper
 
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.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the number of mappings.
MapReduceCacheLoaderTask - Class in org.infinispan.distexec.mapreduce
 
MapReduceCacheLoaderTask(Mapper, Collector) - Constructor for class org.infinispan.distexec.mapreduce.MapReduceCacheLoaderTask
 
MapReduceInitializer - Class in org.infinispan.query.impl.massindex
Initializes the custom Map Reduce tasks we use to rebuild indexes
MapReduceInitializer() - Constructor for class org.infinispan.query.impl.massindex.MapReduceInitializer
 
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
MapReduceMassIndexer - Class in org.infinispan.query.impl.massindex
 
MapReduceMassIndexer(AdvancedCache, SearchFactoryIntegrator) - Constructor for class org.infinispan.query.impl.massindex.MapReduceMassIndexer
 
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.core.Ids
 
markAsOnePhaseCommit() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
markAsOnePhaseCommit() - Method in interface org.infinispan.commands.tx.totalorder.TotalOrderPrepareCommand
marks the prepare phase as 1PC to apply immediately the modifications.
markAsOnePhaseCommit() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
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.commons.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
 
markSkipWriteSkewCheck() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
markSkipWriteSkewCheck() - Method in interface org.infinispan.commands.tx.totalorder.TotalOrderPrepareCommand
it signals that the write skew check is not needed (for versioned entries).
markSkipWriteSkewCheck() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
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.
marshall(StreamingMarshaller, Object) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
 
marshallableTypeHints - Variable in class org.infinispan.commons.marshall.AbstractMarshaller
 
MarshallableTypeHints - Class in org.infinispan.commons.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.commons.marshall.MarshallableTypeHints
 
marshallableTypeHints - Variable in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
marshallCollection(Collection<?>, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
 
MARSHALLED_ENTRY_ID - Static variable in interface org.infinispan.marshall.core.Ids
 
MARSHALLED_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
MarshalledEntry<K,V> - Interface in org.infinispan.marshall.core
Defines an externally persisted entry.
MarshalledEntryFactory<K,V> - Interface in org.infinispan.marshall.core
Factory for MarshalledEntry.
MarshalledEntryFactoryImpl - Class in org.infinispan.marshall.core
 
MarshalledEntryFactoryImpl() - Constructor for class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
MarshalledEntryFactoryImpl(StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
MarshalledEntryImpl<K,V> - Class in org.infinispan.marshall.core
 
MarshalledEntryImpl(ByteBuffer, ByteBuffer, ByteBuffer, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
 
MarshalledEntryImpl(K, ByteBuffer, ByteBuffer, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
 
MarshalledEntryImpl(K, V, InternalMetadata, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
 
MarshalledEntryImpl.Externalizer - Class in org.infinispan.marshall.core
 
MarshalledValue - Class in org.infinispan.marshall.core
Wrapper that wraps cached data, providing lazy deserialization using the calling thread's context class loader.
MarshalledValue() - Constructor for class org.infinispan.marshall.core.MarshalledValue
 
MarshalledValue(byte[], int, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledValue
 
MarshalledValue(byte[], StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledValue
 
MarshalledValue(Object, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledValue
 
MarshalledValue.Externalizer - Class in org.infinispan.marshall.core
 
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.persistence.keymappers
This class is an implementation for TwoWayKey2StringMapper that supports both primitives and MarshalledValues.
MarshalledValueOrPrimitiveMapper() - Constructor for class org.infinispan.persistence.keymappers.MarshalledValueOrPrimitiveMapper
 
marshaller - Variable in class org.infinispan.CacheImpl
 
marshaller(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
marshaller(Marshaller) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
marshaller() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
marshaller(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
marshaller(Marshaller) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
marshaller(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Allows you to specify a custom Marshaller implementation to serialize and deserialize user objects.
marshaller(Class<? extends Marshaller>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Allows you to specify a custom Marshaller implementation to serialize and deserialize user objects.
marshaller(Marshaller) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Allows you to specify an instance of Marshaller to serialize and deserialize user objects.
MARSHALLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
marshaller - Variable in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
Marshaller - Interface in org.infinispan.commons.marshall
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
marshaller() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
marshaller(Marshaller) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
Sets the marshaller instance to be used by the interoperability layer.
marshaller(Marshaller) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
Deprecated.
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 - Interface in org.infinispan.marshall
Deprecated.
marshaller(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
marshaller() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
marshaller(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
marshaller(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Allows you to specify a custom Marshaller implementation to serialize and deserialize user objects.
marshaller(Class<? extends Marshaller>) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Allows you to specify a custom Marshaller implementation to serialize and deserialize user objects.
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() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
MarshallerFactory - Class in org.infinispan.factories
MarshallerFactory.
MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
 
MarshallerRegistration - Class in org.infinispan.query.remote.client
 
MarshallerRegistration() - Constructor for class org.infinispan.query.remote.client.MarshallerRegistration
 
MarshallingTwoWayKey2StringMapper - Interface in org.infinispan.persistence.keymappers
MarshallingTwoWayKey2StringMapper.
marshallMap(Map<?, ?>, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
 
MarshallUtil - Class in org.infinispan.commons.marshall
MarshallUtil.
MarshallUtil() - Constructor for class org.infinispan.commons.marshall.MarshallUtil
 
MassIndexer - Interface in org.infinispan.query
Component to rebuild the indexes from the existing data.
MasterSwitchDelegatingQueueProcessor - Class in org.infinispan.query.indexmanager
Switches between local indexing by delegating to a traditional BackendQueueProcessor or to the custom InfinispanCommandsBackend to delegate to remote nodes.
MasterSwitchDelegatingQueueProcessor(BackendQueueProcessor, InfinispanCommandsBackend) - Constructor for class org.infinispan.query.indexmanager.MasterSwitchDelegatingQueueProcessor
 
matcherForRetry() - Method in enum org.infinispan.commands.write.ValueMatcher
 
matches(MVCCEntry, Object, Object, Equivalence) - Method in enum org.infinispan.commands.write.ValueMatcher
 
matches(String) - Method in enum org.infinispan.configuration.parsing.ParsedCacheMode
 
MAX_BATCH_SIZE - Static variable in interface org.infinispan.util.concurrent.BoundedConcurrentHashMap.EvictionPolicy
 
MAX_ID - Static variable in interface org.infinispan.marshall.core.Ids
 
maxActive() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
maxActive(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Controls the maximum number of connections per server that are allocated (checked out to client threads, or idle in the pool) at one time.
maxActive() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
maxActive(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Controls the maximum number of connections per server that are allocated (checked out to client threads, or idle in the pool) at one time.
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.
maxEntries() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
maxEntries(int) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
In order to speed up lookups, the single file cache store keeps an index of keys and their corresponding position in the file.
maxFailoverAttempts() - Method in interface org.infinispan.distexec.DistributedTaskFailoverPolicy
Maximum number of fail over attempts permitted by this DistributedTaskFailoverPolicy
maxIdle() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
maxIdle(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Controls the maximum number of idle persistent connections, per server, at any time.
maxIdle - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
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.TransientCacheEntry
 
maxIdle - Variable in class org.infinispan.container.entries.TransientCacheValue
 
maxIdle - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
maxIdle - Variable in class org.infinispan.container.entries.TransientMortalCacheValue
 
maxIdle - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxIdle(long, TimeUnit) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxIdle(long) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
maxIdle() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
maxIdle(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
Set max idle time with a given time unit.
maxIdle(long) - Method in interface org.infinispan.metadata.Metadata.Builder
Set max idle time assuming that the time unit is milliseconds.
maxIdle() - Method in interface org.infinispan.metadata.Metadata
Returns the the maximum amount of time that the cache entry associated with this metadata object is allowed to be idle for before it is considered as expired, in milliseconds.
maxIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
maxIdle(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Controls the maximum number of idle persistent connections, per server, at any time.
maxIdleUnit - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxProgressingLogWritesDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
maxProgressingLogWritesDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
maxProgressingLogWritesDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
maxProgressingLogWritesDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
maxProgressingLogWritesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
maxProgressingLogWritesDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
maxProgressingLogWritesDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
maxProgressingLogWritesDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
maxProgressingLogWritesDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
maxProgressingLogWritesDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
maxProgressingLogWritesDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
maxResults(int) - Method in interface org.infinispan.query.CacheQuery
Sets the maximum number of results to the number passed in as a parameter.
maxResults(int) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
maxResults - Variable in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
maxResults(int) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
maxResults(int) - Method in interface org.infinispan.query.dsl.QueryBuilder
 
maxResults(int) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
maxTotal() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
maxTotal(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Sets a global limit on the number persistent connections that can be in circulation within the combined set of servers.
maxTotal() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
maxTotal(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Sets a global limit on the number persistent connections that can be in circulation within the combined set of servers.
maxWait() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
maxWait(long) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
The amount of time in milliseconds to wait for a connection to become available when the exhausted action is ExhaustedAction.WAIT, after which a NoSuchElementException will be thrown.
MBean - Annotation Type in org.infinispan.jmx.annotations
Classes annotated with this will be exposed as MBeans.
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.
mbeansSuccessfullyRegistered() - Method in class org.infinispan.lucene.logging.Log_$logger
 
mbeansSuccessfullyRegistered() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
mbeansSuccessfullyRegistered() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
mbeansSuccessfullyRegistered() - Method in class org.infinispan.query.logging.Log_$logger
 
mbeansSuccessfullyRegistered() - Method in interface org.infinispan.util.logging.Log
 
mbeansSuccessfullyRegistered() - Method in class org.infinispan.util.logging.Log_$logger
 
mbeansSuccessfullyRegistered$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
mbeansSuccessfullyRegistered$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
mbeansSuccessfullyRegistered$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
mbeansSuccessfullyRegistered$str() - Method in class org.infinispan.query.logging.Log_$logger
 
mbeansSuccessfullyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
MeasurementType - Enum in org.infinispan.jmx.annotations
 
members - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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(K, V, EquivalentConcurrentHashMapV8.BiFun<? super V, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
If the specified key is not already associated with a (non-null) value, associates it with the given value.
merge(EntryVersionsMap) - Method in class org.infinispan.container.versioning.EntryVersionsMap
 
Merged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology experiences a merge event after a cluster split.
MergeEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with Merged.
messageId(long) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
metadata - Variable in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
metadata - Variable in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
metadata - Variable in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
metadata - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
Metadata() - Constructor for class org.infinispan.io.GridFile.Metadata
 
Metadata(int, long, int, byte) - Constructor for class org.infinispan.io.GridFile.Metadata
 
metadata - Variable in class org.infinispan.io.GridFilesystem
 
Metadata - Interface in org.infinispan.metadata
This interface encapsulates metadata information that can be stored alongside values in the cache.
Metadata.Builder - Interface in org.infinispan.metadata
Metadata builder
METADATA_IMMORTAL_ENTRY - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_IMMORTAL_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_TRANSIENT_ENTRY - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
METADATA_TRANSIENT_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
MetadataAware - Interface in org.infinispan.container.entries.metadata
Metdata aware cache entry.
MetadataAwareCommand - Interface in org.infinispan.commands
A command that contains metadata information.
MetadataImmortalCacheEntry - Class in org.infinispan.container.entries.metadata
MetadataImmortalCacheEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
MetadataImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataImmortalCacheValue - Class in org.infinispan.container.entries.metadata
MetadataImmortalCacheValue(Object, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
MetadataImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataMortalCacheEntry - Class in org.infinispan.container.entries.metadata
A cache entry that is mortal and is MetadataAware
MetadataMortalCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
MetadataMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataMortalCacheValue - Class in org.infinispan.container.entries.metadata
A mortal cache value, to correspond with MetadataMortalCacheEntry
MetadataMortalCacheValue(Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
MetadataMortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
 
Metadatas - Class in org.infinispan.metadata
Utility method for Metadata classes.
MetadataTransientCacheEntry - Class in org.infinispan.container.entries.metadata
A cache entry that is transient, i.e., it can be considered expired after a period of not being used, and MetadataAware
MetadataTransientCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
MetadataTransientCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataTransientCacheValue - Class in org.infinispan.container.entries.metadata
A transient cache value, to correspond with TransientCacheEntry which is MetadataAware
MetadataTransientCacheValue(Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
MetadataTransientCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataTransientMortalCacheEntry - Class in org.infinispan.container.entries.metadata
MetadataTransientMortalCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
MetadataTransientMortalCacheEntry(Object, Object, Metadata, long, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
MetadataTransientMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataTransientMortalCacheValue - Class in org.infinispan.container.entries.metadata
MetadataTransientMortalCacheValue(Object, Metadata, long, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
MetadataTransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
 
MetadataValue<V> - Interface in org.infinispan.client.hotrod
Besides the value, also contains a version and expiration information.
MetadataValueImpl<V> - Class in org.infinispan.client.hotrod.impl
MetadataValueImpl.
MetadataValueImpl(long, int, long, int, long, V) - Constructor for class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
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
 
minEvictableIdleTime() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
minEvictableIdleTime(long) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Specifies the minimum amount of time that an connection may sit idle in the pool before it is eligible for eviction due to idle time.
minEvictableIdleTime() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
minEvictableIdleTime(long) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Specifies the minimum amount of time that an connection may sit idle in the pool before it is eligible for eviction due to idle time.
minIdle() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
minIdle(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Sets a target value for the minimum number of idle connections (per server) that should always be available.
minIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
minIdle(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Sets a target value for the minimum number of idle connections (per server) that should always be available.
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.
MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get misses.
missingConnectionFactory() - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
missingConnectionFactory() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingConnectionFactory$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in class org.infinispan.query.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in interface org.infinispan.util.logging.Log
 
missingCustomInterceptorPosition(String) - Method in class org.infinispan.util.logging.Log_$logger
 
missingCustomInterceptorPosition$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingCustomInterceptorPosition$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingCustomInterceptorPosition$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingCustomInterceptorPosition$str() - Method in class org.infinispan.query.logging.Log_$logger
 
missingCustomInterceptorPosition$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in class org.infinispan.query.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in interface org.infinispan.util.logging.Log
 
missingForeignExternalizer(int) - Method in class org.infinispan.util.logging.Log_$logger
 
missingForeignExternalizer$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingForeignExternalizer$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingForeignExternalizer$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingForeignExternalizer$str() - Method in class org.infinispan.query.logging.Log_$logger
 
missingForeignExternalizer$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingKeyStorePassword(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
missingKeyStorePassword(String) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
missingKeyStorePassword$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in class org.infinispan.query.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in interface org.infinispan.util.logging.Log
 
missingListPreparedTransactions(Object, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
missingListPreparedTransactions$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingListPreparedTransactions$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingListPreparedTransactions$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingListPreparedTransactions$str() - Method in class org.infinispan.query.logging.Log_$logger
 
missingListPreparedTransactions$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingMigrationData(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingMigrationData(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingMigrationData(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingMigrationData(String) - Method in class org.infinispan.query.logging.Log_$logger
 
missingMigrationData(String) - Method in interface org.infinispan.util.logging.Log
 
missingMigrationData(String) - Method in class org.infinispan.util.logging.Log_$logger
 
missingMigrationData$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
missingMigrationData$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
missingMigrationData$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
missingMigrationData$str() - Method in class org.infinispan.query.logging.Log_$logger
 
missingMigrationData$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
missingTrustStorePassword(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
missingTrustStorePassword(String) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
missingTrustStorePassword$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
mkdir() - Method in class org.infinispan.io.GridFile
 
mkdirs() - Method in class org.infinispan.io.GridFile
 
mod(int, int) - Static method in class org.infinispan.io.ModularArithmetic
 
mod(long, int) - Static method in class org.infinispan.io.ModularArithmetic
 
Modification - Interface in org.infinispan.persistence.modifications
An interface that defines a CacheWriter modification
Modification.Type - Enum in org.infinispan.persistence.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.
modifications - Variable in class org.infinispan.commands.tx.PrepareCommand
 
modifications - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
ModificationsList - Class in org.infinispan.persistence.modifications
ModificationsList contains a List
ModificationsList(List<? extends Modification>) - Constructor for class org.infinispan.persistence.modifications.ModificationsList
 
ModularArithmetic - Class in org.infinispan.io
For compatibility
ModularArithmetic() - Constructor for class org.infinispan.io.ModularArithmetic
 
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.
ModuleCommandIds - Interface in org.infinispan.query.impl
The Query module is using custom RPC commands; to make sure the used command ids are unique all numbers are defined here, and should stay in the range 100-119 which is the reserved range for this module.
ModuleCommandInitializer - Interface in org.infinispan.commands.module
Modules which wish to implement their own commands and visitors must also provide an implementation of this interface and declare it in their infinispan-module.properties file under key infinispan.module.command.initializer.
moduleCommandInitializers() - Method in class org.infinispan.util.ModuleProperties
 
moduleCommands() - Method in class org.infinispan.util.ModuleProperties
 
ModuleLifecycle - Interface in org.infinispan.lifecycle
ModuleLifecycle is an internal API hook for delegating lifecycle events to Infinispan sub-modules.
ModuleMetadataFileFinder - Interface in org.infinispan.factories.components
This interface should be implemented by all Infinispan modules that expect to have components using Inject, Start or Stop annotations.
moduleOnlyReplicableCommands() - Method in class org.infinispan.util.ModuleProperties
 
ModuleProperties - Class in org.infinispan.util
The ModuleProperties class represents Infinispan's module service extensions
ModuleProperties() - Constructor for class org.infinispan.util.ModuleProperties
 
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.core.Ids
 
MORTAL_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
MortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is mortal.
MortalCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheEntry
 
MortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
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
 
msgOrMsgBufferEmpty() - Method in class org.infinispan.lucene.logging.Log_$logger
 
msgOrMsgBufferEmpty() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
msgOrMsgBufferEmpty() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
msgOrMsgBufferEmpty() - Method in class org.infinispan.query.logging.Log_$logger
 
msgOrMsgBufferEmpty() - Method in interface org.infinispan.util.logging.Log
 
msgOrMsgBufferEmpty() - Method in class org.infinispan.util.logging.Log_$logger
 
msgOrMsgBufferEmpty$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
msgOrMsgBufferEmpty$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
msgOrMsgBufferEmpty$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
msgOrMsgBufferEmpty$str() - Method in class org.infinispan.query.logging.Log_$logger
 
msgOrMsgBufferEmpty$str() - Method in class org.infinispan.util.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState() - Method in class org.infinispan.lucene.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState() - Method in class org.infinispan.query.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState() - Method in interface org.infinispan.util.logging.Log
 
multipleCacheStoresWithFetchPersistentState() - Method in class org.infinispan.util.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState$str() - Method in class org.infinispan.query.logging.Log_$logger
 
multipleCacheStoresWithFetchPersistentState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
multipleCustomInterceptorPositions(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
multipleCustomInterceptorPositions(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
multipleCustomInterceptorPositions(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
multipleCustomInterceptorPositions(String) - Method in class org.infinispan.query.logging.Log_$logger
 
multipleCustomInterceptorPositions(String) - Method in interface org.infinispan.util.logging.Log
 
multipleCustomInterceptorPositions(String) - Method in class org.infinispan.util.logging.Log_$logger
 
multipleCustomInterceptorPositions$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
multipleCustomInterceptorPositions$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
multipleCustomInterceptorPositions$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
multipleCustomInterceptorPositions$str() - Method in class org.infinispan.query.logging.Log_$logger
 
multipleCustomInterceptorPositions$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
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
 
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
 
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_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.commons.marshall.Ids
 
MURMURHASH_2_COMPAT - Static variable in interface org.infinispan.commons.marshall.Ids
 
MURMURHASH_3 - Static variable in interface org.infinispan.commons.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_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
namedCacheDoesNotExist(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
namedCacheDoesNotExist(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
namedCacheDoesNotExist(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
namedCacheDoesNotExist(String) - Method in class org.infinispan.query.logging.Log_$logger
 
namedCacheDoesNotExist(String) - Method in interface org.infinispan.util.logging.Log
 
namedCacheDoesNotExist(String) - Method in class org.infinispan.util.logging.Log_$logger
 
namedCacheDoesNotExist$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
namedCacheDoesNotExist$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
namedCacheDoesNotExist$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
namedCacheDoesNotExist$str() - Method in class org.infinispan.query.logging.Log_$logger
 
namedCacheDoesNotExist$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 - Annotation Type in org.infinispan.configuration.parsing
Namespace.
NamespaceMappingParser - Interface in org.infinispan.configuration.parsing
NamespaceMappingParser.
Namespaces - Annotation Type in org.infinispan.configuration.parsing
Namespaces.
namingExceptionLookingUpConnection(String, NamingException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
namingExceptionLookingUpConnection(String, NamingException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
namingExceptionLookingUpConnection$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
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 class org.infinispan.remoting.responses.KeysValidateFilter
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.SelfDeliverFilter
 
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
 
needsCredentials() - Method in interface org.infinispan.cli.connection.Connection
 
needsCredentials() - Method in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
needsCredentials() - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
needsCredentials() - Method in interface org.infinispan.cli.connection.jmx.JMXUrl
 
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
 
nesting() - Method in class org.infinispan.cli.commands.server.Abort
 
nesting() - Method in class org.infinispan.cli.commands.server.Begin
 
nesting() - Method in class org.infinispan.cli.commands.server.Cache
 
nesting() - Method in class org.infinispan.cli.commands.server.Clear
 
nesting() - Method in class org.infinispan.cli.commands.server.Commit
 
nesting() - Method in class org.infinispan.cli.commands.server.Create
 
nesting() - Method in class org.infinispan.cli.commands.server.Encoding
 
nesting() - Method in class org.infinispan.cli.commands.server.End
 
nesting() - Method in class org.infinispan.cli.commands.server.Evict
 
nesting() - Method in class org.infinispan.cli.commands.server.Get
 
nesting() - Method in class org.infinispan.cli.commands.server.Info
 
nesting() - Method in class org.infinispan.cli.commands.server.Locate
 
nesting() - Method in class org.infinispan.cli.commands.server.Ping
 
nesting() - Method in class org.infinispan.cli.commands.server.Put
 
nesting() - Method in class org.infinispan.cli.commands.server.Remove
 
nesting() - Method in class org.infinispan.cli.commands.server.Replace
 
nesting() - Method in class org.infinispan.cli.commands.server.Rollback
 
nesting() - Method in class org.infinispan.cli.commands.server.Site
 
nesting() - Method in class org.infinispan.cli.commands.server.Start
 
nesting() - Method in class org.infinispan.cli.commands.server.Stats
 
nesting() - Method in class org.infinispan.cli.commands.server.Upgrade
 
nesting() - Method in class org.infinispan.cli.commands.server.Version
 
nesting() - Method in interface org.infinispan.cli.commands.ServerCommand
 
newBulkGetKeysOperation(int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newBulkGetOperation(int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newByteBuffer(byte[], int, int) - Method in interface org.infinispan.commons.io.ByteBufferFactory
 
newByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.io.ByteBufferFactoryImpl
 
newCatchThrowableProxy(Object) - Static method in class org.infinispan.commons.util.Proxies
 
newClearOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newCondition() - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
newConfigurationBuilder(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
newConsistentHash(int) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashFactory
 
newContainsKeyOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newDirectoryInstance(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String) - Static method in class org.infinispan.lucene.directory.DirectoryBuilder
Starting point to create a Directory instance.
newFaultTolerantPingOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
Construct a fault tolerant ping request.
newFixedThreadPool(int, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue.
newFixedThreadPool(int, ThreadFactory, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue, using the provided ThreadFactory to create new threads when needed.
newGetKeyOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGetWithMetadataOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGetWithVersionOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newGlobalTransaction() - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newGlobalTransaction(Address, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newGlobalTransaction(Address, boolean, VersionGenerator, boolean) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newGlobalTransaction() - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
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.commons.util.FileLookupFactory
 
newInstance() - Static method in class org.infinispan.util.FileLookupFactory
Deprecated.
 
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(Equivalence<K>) - Static method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Creates a new Set backed by a EquivalentConcurrentHashMapV8 from the given type to Boolean.TRUE.
newKeySet(int, Equivalence<K>) - Static method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Creates a new Set backed by a EquivalentConcurrentHashMapV8 from the given type to Boolean.TRUE.
NEWLINE - Static variable in class org.infinispan.commons.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, Equivalence<Object>) - 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
 
newMarshalledEntry(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
 
newMarshalledEntry(Object, ByteBuffer, ByteBuffer) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
 
newMarshalledEntry(Object, Object, InternalMetadata) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
 
newMarshalledEntry(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
newMarshalledEntry(Object, ByteBuffer, ByteBuffer) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
newMarshalledEntry(Object, Object, InternalMetadata) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
newNonTxInvocationContext(boolean) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
 
newPingOperation(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
Construct a ping request directed to a particular node.
newPutIfAbsentOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newPutKeyValueOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newQueryOperation(RemoteQuery) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newRemoteTransaction(WriteCommand[], GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newRemoteTransaction(GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newRemoteTransaction(WriteCommand[], GlobalTransaction, int, Equivalence<Object>) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newRemoteTransaction(GlobalTransaction, int, Equivalence<Object>) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newRemoveIfUnmodifiedOperation(byte[], long) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newRemoveOperation(byte[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newReplaceIfUnmodifiedOperation(byte[], byte[], int, int, long) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newReplaceOperation(byte[], byte[], int, int) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newServerAdded(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
newServerAdded(SocketAddress) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
newServerAdded$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
newStatsOperation() - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
newTaskFor(Runnable, T) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
 
newTaskFor(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
 
newTaskFor(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
newThread(ForkJoinPool) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
newTopology(SocketAddress, int, int, Set<SocketAddress>) - Method in interface org.infinispan.client.hotrod.logging.Log
 
newTopology(SocketAddress, int, int, Set) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
newTopology$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
next(int) - Method in class org.infinispan.commons.util.concurrent.jdk7backported.ThreadLocalRandom
 
next() - Method in class org.infinispan.container.DefaultDataContainer.EntryIterator
 
next() - Method in class org.infinispan.query.clustered.DistributedIterator
 
next() - Method in class org.infinispan.query.impl.AbstractIterator
 
next() - Method in class org.infinispan.query.impl.NullFilteringIterator
 
next() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
nextComplete() - Method in class org.infinispan.commons.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.commons.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.commons.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.commons.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.commons.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.commons.util.concurrent.jdk7backported.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextServer() - Method in interface org.infinispan.client.hotrod.impl.transport.tcp.RequestBalancingStrategy
 
nextServer() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
Multiple threads might call this method at the same time.
nextSize(Object) - Method in class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
 
nextSize(Object) - Method in interface org.infinispan.commons.marshall.BufferSizePredictor
Provide the next buffer size taking in account the object to store in the buffer.
nextSize(Object) - Method in interface org.infinispan.marshall.BufferSizePredictor
Deprecated.
Provide the next buffer size taking in account the object to store in the buffer.
nextSize(Object) - Method in class org.infinispan.marshall.BufferSizePredictorAdapter
Deprecated.
 
nextSize(Object) - Method in class org.infinispan.marshall.CommonsBufferSizePredictorAdapter
Deprecated.
 
nextSize(Object) - Method in class org.infinispan.marshall.LegacyBufferSizePredictorAdapter
Deprecated.
 
NO_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
NO_FAILOVER - Static variable in class org.infinispan.distexec.DefaultExecutorService
 
NO_OPTIONS - Static variable in class org.infinispan.commons.util.Base64
No options specified.
noAnnotateMethodsFoundInListener(Class) - Method in class org.infinispan.lucene.logging.Log_$logger
 
noAnnotateMethodsFoundInListener(Class) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
noAnnotateMethodsFoundInListener(Class) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
noAnnotateMethodsFoundInListener(Class) - Method in class org.infinispan.query.logging.Log_$logger
 
noAnnotateMethodsFoundInListener(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
noAnnotateMethodsFoundInListener(Class) - Method in class org.infinispan.util.logging.Log_$logger
 
noAnnotateMethodsFoundInListener$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
noAnnotateMethodsFoundInListener$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
noAnnotateMethodsFoundInListener$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
noAnnotateMethodsFoundInListener$str() - Method in class org.infinispan.query.logging.Log_$logger
 
noAnnotateMethodsFoundInListener$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noDataLossOnJoiner(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
Node(K, int, V) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap.Node
 
nodeName() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
nodeName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Name of the current node.
noHasHFunctionConfigured(int) - Method in interface org.infinispan.client.hotrod.logging.Log
 
noHasHFunctionConfigured(int) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
noHasHFunctionConfigured$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
noLiveOwnersFoundForSegment(int, String, Collection, Collection) - Method in class org.infinispan.lucene.logging.Log_$logger
 
noLiveOwnersFoundForSegment(int, String, Collection, Collection) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
noLiveOwnersFoundForSegment(int, String, Collection, Collection) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
noLiveOwnersFoundForSegment(int, String, Collection, Collection) - Method in class org.infinispan.query.logging.Log_$logger
 
noLiveOwnersFoundForSegment(int, String, Collection<Address>, Collection<Address>) - Method in interface org.infinispan.util.logging.Log
 
noLiveOwnersFoundForSegment(int, String, Collection, Collection) - Method in class org.infinispan.util.logging.Log_$logger
 
noLiveOwnersFoundForSegment$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
noLiveOwnersFoundForSegment$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
noLiveOwnersFoundForSegment$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
noLiveOwnersFoundForSegment$str() - Method in class org.infinispan.query.logging.Log_$logger
 
noLiveOwnersFoundForSegment$str() - Method in class org.infinispan.util.logging.Log_$logger
 
NON_EXISTING_VERSION - Static variable in interface org.infinispan.marshall.core.Ids
 
nonClusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
nonExistentEntryCanMatch() - Method in enum org.infinispan.commands.write.ValueMatcher
 
nonExistingVersion() - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
nonExistingVersion() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
nonExistingVersion() - Method in interface org.infinispan.container.versioning.VersionGenerator
 
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
 
NonTransactionalInvocationContextFactory - Class in org.infinispan.context
Invocation Context container to be used for non-transactional caches.
NonTransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.NonTransactionalInvocationContextFactory
 
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
 
NonTxDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Non-transactional interceptor used by distributed caches that support concurrent writes.
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, Equivalence<Object>) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NonTxInvocationContext(Equivalence<Object>) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NoOpFuture<E> - Class in org.infinispan.commons.util.concurrent
A future that doesn't do anything and simply returns a given return value.
NoOpFuture(E) - Constructor for class org.infinispan.commons.util.concurrent.NoOpFuture
 
NoopSegmentReadLocker - Class in org.infinispan.lucene.readlocks
NoopSegmentReadLocker ignores requests to apply a readlock, but also ignores requests to delete files.
NoopSegmentReadLocker() - Constructor for class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
 
NoReturnValuesDistributionResponseGenerator - Class in org.infinispan.remoting.responses
 
NoReturnValuesDistributionResponseGenerator() - Constructor for class org.infinispan.remoting.responses.NoReturnValuesDistributionResponseGenerator
 
normalizedHash(Hash, int) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
noSSLKeyManagerConfiguration() - Method in interface org.infinispan.client.hotrod.logging.Log
 
noSSLKeyManagerConfiguration() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
noSSLKeyManagerConfiguration$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
noSSLTrustManagerConfiguration() - Method in interface org.infinispan.client.hotrod.logging.Log
 
noSSLTrustManagerConfiguration() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
noSSLTrustManagerConfiguration$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
NoStateExternalizer<T> - Class in org.infinispan.commons.marshall.exts
An externalizer that writes no state.
NoStateExternalizer() - Constructor for class org.infinispan.commons.marshall.exts.NoStateExternalizer
 
not() - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
 
not(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
 
not() - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
not(FilterConditionContext) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
not() - Method in class org.infinispan.query.dsl.impl.BaseQueryFactory
 
not(FilterConditionContext) - Method in class org.infinispan.query.dsl.impl.BaseQueryFactory
 
not() - Method in interface org.infinispan.query.dsl.QueryFactory
Creates a negated condition that is to be completed later by using it as a sub-condition.
not(FilterConditionContext) - Method in interface org.infinispan.query.dsl.QueryFactory
Creates a negated condition based on a given sub-condition.
NOT_PUT_REMOVED_REPLACED_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
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, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntriesEvicted event.
notifyCacheEntriesEvicted(Collection<InternalCacheEntry>, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryActivated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryActivated event.
notifyCacheEntryActivated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryCreated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryCreated event.
notifyCacheEntryCreated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryEvicted(Object, Object, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Syntactic sugar
notifyCacheEntryEvicted(Object, Object, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryInvalidated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryInvalidated event.
notifyCacheEntryInvalidated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryLoaded(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryLoaded event.
notifyCacheEntryLoaded(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryModified(Object, Object, boolean, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryModified event.
notifyCacheEntryModified(Object, Object, boolean, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryPassivated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryPassivated event.
notifyCacheEntryPassivated(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryRemoved(Object, Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryRemoved event.
notifyCacheEntryRemoved(Object, Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryVisited(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryVisited event.
notifyCacheEntryVisited(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - 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, FlagAffectedCommand) - 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.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
notifyDone() - Method in class org.infinispan.commons.util.concurrent.BaseNotifyingFuture
 
notifyDone() - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
notifyDone() - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
notifyDone() - Method in interface org.infinispan.commons.util.concurrent.NotifyingNotifiableFuture
 
notifyEndOfRebalance(int) - Method in interface org.infinispan.statetransfer.StateTransferManager
 
notifyEndOfRebalance(int) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
notifyFutureCompletion() - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
NotifyingFuture<T> - Interface in org.infinispan.commons.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.
NotifyingFuture<T> - Interface in org.infinispan.util.concurrent
Deprecated.
Use NotifyingFuture instead
NotifyingFutureAdaptor<T> - Class in org.infinispan.commons.util.concurrent
Receives a Future and exposes it as an NotifyingFuture.
NotifyingFutureAdaptor() - Constructor for class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
NotifyingFutureImpl<T> - Class in org.infinispan.client.hotrod.impl.async
Notifying future implementation for async calls.
NotifyingFutureImpl() - Constructor for class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
NotifyingFutureImpl<T> - Class in org.infinispan.commons.util.concurrent
Constructs an instance of a NotifyingFuture.
NotifyingFutureImpl(T) - Constructor for class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
NotifyingNotifiableFuture<T> - Interface in org.infinispan.commons.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
 
notifyStateTransferEnd() - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
It notifies the end of the state transfer possibly unblock waiting prepares.
notifyStateTransferStart(int) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
It notifies that a state transfer is about to start.
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
 
notNull(AdvancedCacheLoader.KeyFilter) - Static method in class org.infinispan.persistence.PersistenceUtil
 
NotSerializableException - Exception in org.infinispan.commons.marshall
An exception that hides inner stacktrace lines for non serializable exceptions.
NotSerializableException(String, Throwable) - Constructor for exception org.infinispan.commons.marshall.NotSerializableException
 
NotSerializableException(String) - Constructor for exception org.infinispan.commons.marshall.NotSerializableException
 
notStartingEvictionThread() - Method in class org.infinispan.lucene.logging.Log_$logger
 
notStartingEvictionThread() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
notStartingEvictionThread() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
notStartingEvictionThread() - Method in class org.infinispan.query.logging.Log_$logger
 
notStartingEvictionThread() - Method in interface org.infinispan.util.logging.Log
 
notStartingEvictionThread() - Method in class org.infinispan.util.logging.Log_$logger
 
notStartingEvictionThread$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
notStartingEvictionThread$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
notStartingEvictionThread$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
notStartingEvictionThread$str() - Method in class org.infinispan.query.logging.Log_$logger
 
notStartingEvictionThread$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noTxModifications(InvocationContext) - Static method in class org.infinispan.commands.read.AbstractLocalCommand
 
NullDelta - Enum in org.infinispan.atomic
Represents no changes.
NullFilteringIterator<E> - Class in org.infinispan.query.impl
An iterator wrapper that filters out (skips over) any null values returned by the wrapped iterator.
NullFilteringIterator(Iterator<E>) - Constructor for class org.infinispan.query.impl.NullFilteringIterator
 
NullFilteringResultIterator - Class in org.infinispan.query.impl
 
NullFilteringResultIterator(ResultIterator) - Constructor for class org.infinispan.query.impl.NullFilteringResultIterator
 
nullIfEmpty(String) - Static method in class org.infinispan.cli.util.Utils
Returns null if the parameter is null or empty, otherwise it returns it untouched
NUMERIC_VERSION - Static variable in interface org.infinispan.marshall.core.Ids
 
NumericVersion - Class in org.infinispan.container.versioning
Numeric version
NumericVersion(long) - Constructor for class org.infinispan.container.versioning.NumericVersion
 
NumericVersion.Externalizer - Class in org.infinispan.container.versioning
 
NumericVersionGenerator - Class in org.infinispan.container.versioning
Generates unique numeric versions for both local and clustered environments.
NumericVersionGenerator() - Constructor for class org.infinispan.container.versioning.NumericVersionGenerator
 
NumericVersionGenerator.RankCalculator - Class in org.infinispan.container.versioning
 
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.
numRetriesDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
numRetriesDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
numRetriesDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
numRetriesDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
numRetriesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
numRetriesDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
numRetriesDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
numRetriesDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
numRetriesDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
numRetriesDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
numRetriesDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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).
numTestsPerEvictionRun() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
numTestsPerEvictionRun(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Indicates the maximum number of connections to test during idle eviction runs.
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.commons.util
A helper that efficiently duplicates known object types.
ObjectDuplicator() - Constructor for class org.infinispan.commons.util.ObjectDuplicator
 
objectFromBuffer(byte[], int, int) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
objectFromByteBuffer(byte[]) - Method in interface org.infinispan.commons.marshall.Marshaller
Unmarshalls an object from a byte array.
objectFromByteBuffer(byte[], int, int) - Method in interface org.infinispan.commons.marshall.Marshaller
Unmarshalls an object from a specific portion of a byte array.
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectFromByteBuffer(byte[]) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
Unmarshalls an object from a byte array.
objectFromByteBuffer(byte[], int, int) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
Unmarshalls an object from a specific portion of a byte array.
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
 
objectFromInputStream(InputStream) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectFromInputStream(InputStream) - Method in class org.infinispan.commons.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.commons.marshall.StreamingMarshaller
Unmarshall an object from an InputStream
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
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 class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectFromInputStream(InputStream) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Unmarshall an object from an InputStream
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Unmarshalls an object from an ObjectInput
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Unmarshalls an object from an ObjectInput
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectToBuffer(Object, int) - Method in class org.infinispan.client.hotrod.marshall.ApacheAvroMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
This is a convenience method for converting an object into a org.infinispan.io.ByteBuffer which takes an estimated size as parameter.
objectToBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
objectToBuffer(Object) - Method in interface org.infinispan.commons.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.AbstractMarshaller
Deprecated.
This is a convenience method for converting an object into a ByteBufferImpl which takes an estimated size as parameter.
objectToBuffer(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
objectToBuffer(Object, int) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
objectToBuffer(Object) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectToBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
A method that returns an instance of ByteBufferImpl, which allows direct access to the byte array with minimal array copying
objectToBuffer(Object) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectToBuffer(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
objectToBuffer(Object, int) - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
 
objectToBuffer(Object) - Method in class org.infinispan.remoting.transport.jgroups.MarshallerAdapter
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
 
objectToByteBuffer(Object, int) - Method in interface org.infinispan.commons.marshall.Marshaller
Marshalls an object to a byte array.
objectToByteBuffer(Object) - Method in interface org.infinispan.commons.marshall.Marshaller
Marshalls an object to a byte array.
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.AbstractMarshaller
Deprecated.
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.LegacyMarshallerAdapter
Deprecated.
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectToByteBuffer(Object, int) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
Marshalls an object to a byte array.
objectToByteBuffer(Object) - Method in interface org.infinispan.marshall.Marshaller
Deprecated.
Marshalls an object to a byte array.
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Marshalls an object to a given ObjectOutput
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Marshalls an object to a given ObjectOutput
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
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, TimeService) - 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.commons.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
 
onEntryValueReplaced(Object, InternalCacheEntry) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
onEntryValueReplaced(Object, InternalCacheEntry) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
onePhaseCommit - Variable in class org.infinispan.commands.tx.PrepareCommand
 
onExceptionalCompletion(Throwable, CountedCompleter<?>) - Method in class org.infinispan.commons.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
 
onlyPrimary - Variable in class org.infinispan.notifications.AbstractListenerImpl.ListenerInvocation
 
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
 
onPostExecute(Mapper<KIn, VIn, KOut, VOut>) - Method in class org.infinispan.query.impl.massindex.MapReduceInitializer
 
onPostExecute(Reducer<KOut, VOut>) - Method in class org.infinispan.query.impl.massindex.MapReduceInitializer
 
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
 
onPreExecute(Mapper<KIn, VIn, KOut, VOut>, Cache<KIn, VIn>) - Method in class org.infinispan.query.impl.massindex.MapReduceInitializer
 
onPreExecute(Reducer<KOut, VOut>, Cache<?, ?>) - Method in class org.infinispan.query.impl.massindex.MapReduceInitializer
 
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.commons.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.commons.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
 
opCode(short) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
openInput(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV3Adaptor
 
openInput(String) - Method in class org.infinispan.lucene.cacheloader.DirectoryV4Adaptor
 
openInput(String) - Method in interface org.infinispan.lucene.cacheloader.InternalDirectoryContract
 
openInput(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
Operation<K,V> - Class in org.infinispan.atomic
An atomic operation.
Operation() - Constructor for class org.infinispan.atomic.Operation
 
OperationsFactory - Class in org.infinispan.client.hotrod.impl.operations
Factory for HotRodOperation objects.
OperationsFactory(TransportFactory, String, AtomicInteger, boolean, Codec) - Constructor for class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
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
 
or() - Method in interface org.infinispan.query.dsl.FilterConditionContext
Creates a new context and connects it with the current one using boolean OR.
or(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
Connects a given context with the current one using boolean OR.
orderBy(String, SortOrder) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
orderBy(String, SortOrder) - Method in interface org.infinispan.query.dsl.QueryBuilder
 
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 BatchingCache.startBatch() and BatchingCache.endBatch(boolean) API.
org.infinispan.checkstyle.checks.regexp - package org.infinispan.checkstyle.checks.regexp
 
org.infinispan.checkstyle.filters - package org.infinispan.checkstyle.filters
 
org.infinispan.cli - package org.infinispan.cli
 
org.infinispan.cli.commands - package org.infinispan.cli.commands
 
org.infinispan.cli.commands.client - package org.infinispan.cli.commands.client
 
org.infinispan.cli.commands.server - package org.infinispan.cli.commands.server
 
org.infinispan.cli.connection - package org.infinispan.cli.connection
 
org.infinispan.cli.connection.jmx - package org.infinispan.cli.connection.jmx
 
org.infinispan.cli.connection.jmx.remoting - package org.infinispan.cli.connection.jmx.remoting
 
org.infinispan.cli.connection.jmx.rmi - package org.infinispan.cli.connection.jmx.rmi
 
org.infinispan.cli.impl - package org.infinispan.cli.impl
 
org.infinispan.cli.io - package org.infinispan.cli.io
 
org.infinispan.cli.shell - package org.infinispan.cli.shell
 
org.infinispan.cli.util - package org.infinispan.cli.util
 
org.infinispan.client.hotrod - package org.infinispan.client.hotrod
 
org.infinispan.client.hotrod.configuration - package org.infinispan.client.hotrod.configuration
 
org.infinispan.client.hotrod.exceptions - package org.infinispan.client.hotrod.exceptions
 
org.infinispan.client.hotrod.impl - package org.infinispan.client.hotrod.impl
 
org.infinispan.client.hotrod.impl.async - package org.infinispan.client.hotrod.impl.async
 
org.infinispan.client.hotrod.impl.consistenthash - package org.infinispan.client.hotrod.impl.consistenthash
 
org.infinispan.client.hotrod.impl.operations - package org.infinispan.client.hotrod.impl.operations
 
org.infinispan.client.hotrod.impl.protocol - package org.infinispan.client.hotrod.impl.protocol
 
org.infinispan.client.hotrod.impl.query - package org.infinispan.client.hotrod.impl.query
 
org.infinispan.client.hotrod.impl.transport - package org.infinispan.client.hotrod.impl.transport
 
org.infinispan.client.hotrod.impl.transport.tcp - package org.infinispan.client.hotrod.impl.transport.tcp
 
org.infinispan.client.hotrod.logging - package org.infinispan.client.hotrod.logging
 
org.infinispan.client.hotrod.marshall - package org.infinispan.client.hotrod.marshall
 
org.infinispan.commands - package org.infinispan.commands
Commands that operate on the cache, either locally or remotely.
org.infinispan.commands.control - package org.infinispan.commands.control
 
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.tx.totalorder - package org.infinispan.commands.tx.totalorder
 
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.api - package org.infinispan.commons.api
 
org.infinispan.commons.configuration - package org.infinispan.commons.configuration
 
org.infinispan.commons.equivalence - package org.infinispan.commons.equivalence
Equivalence classes and interfaces to enable equivalence comparison between native types, arrays, etc.
org.infinispan.commons.executors - package org.infinispan.commons.executors
 
org.infinispan.commons.hash - package org.infinispan.commons.hash
 
org.infinispan.commons.io - package org.infinispan.commons.io
 
org.infinispan.commons.logging - package org.infinispan.commons.logging
 
org.infinispan.commons.marshall - package org.infinispan.commons.marshall
Provides Infinispan-specific input and output streams, buffers and related utilities.
org.infinispan.commons.marshall.exts - package org.infinispan.commons.marshall.exts
 
org.infinispan.commons.marshall.jboss - package org.infinispan.commons.marshall.jboss
Hooks to bridge Infinispan's marshalling APIs with JBoss Marshalling internals.
org.infinispan.commons.util - package org.infinispan.commons.util
 
org.infinispan.commons.util.concurrent - package org.infinispan.commons.util.concurrent
 
org.infinispan.commons.util.concurrent.jdk7backported - package org.infinispan.commons.util.concurrent.jdk7backported
 
org.infinispan.commons.util.concurrent.jdk8backported - package org.infinispan.commons.util.concurrent.jdk8backported
 
org.infinispan.compat - package org.infinispan.compat
 
org.infinispan.configuration.cache - package org.infinispan.configuration.cache
 
org.infinispan.configuration.format - package org.infinispan.configuration.format
 
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.metadata - package org.infinispan.container.entries.metadata
 
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.compat - package org.infinispan.interceptors.compat
 
org.infinispan.interceptors.distribution - package org.infinispan.interceptors.distribution
 
org.infinispan.interceptors.locking - package org.infinispan.interceptors.locking
 
org.infinispan.interceptors.totalorder - package org.infinispan.interceptors.totalorder
 
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.lucene - package org.infinispan.lucene
Lucene Directory implementation which stores the index in Infinispan.
org.infinispan.lucene.cacheloader - package org.infinispan.lucene.cacheloader
 
org.infinispan.lucene.cacheloader.configuration - package org.infinispan.lucene.cacheloader.configuration
 
org.infinispan.lucene.directory - package org.infinispan.lucene.directory
 
org.infinispan.lucene.impl - package org.infinispan.lucene.impl
 
org.infinispan.lucene.locking - package org.infinispan.lucene.locking
Lucene's IndexWriter instances are threadsafe but you can have only one open on the index, so when opening an IndexWriter an index-wide lock needs to be acquired.
org.infinispan.lucene.logging - package org.infinispan.lucene.logging
 
org.infinispan.lucene.readlocks - package org.infinispan.lucene.readlocks
Several implementations for a SegmentReadLocker, pick one depending on your use case.
org.infinispan.manager - package org.infinispan.manager
Cache manager package
org.infinispan.marshall - package org.infinispan.marshall
 
org.infinispan.marshall.core - package org.infinispan.marshall.core
 
org.infinispan.marshall.exts - package org.infinispan.marshall.exts
Externalizers for various JDK types that are marshalled using the marshalling framework.
org.infinispan.metadata - package org.infinispan.metadata
 
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.persistence - package org.infinispan.persistence
This package contains stores, which are used for overflow or persistence.
org.infinispan.persistence.async - package org.infinispan.persistence.async
 
org.infinispan.persistence.cli - package org.infinispan.persistence.cli
 
org.infinispan.persistence.cli.configuration - package org.infinispan.persistence.cli.configuration
 
org.infinispan.persistence.cli.upgrade - package org.infinispan.persistence.cli.upgrade
 
org.infinispan.persistence.cluster - package org.infinispan.persistence.cluster
A CacheLoader (not CacheStore) that polls other nodes in the cluster for state.
org.infinispan.persistence.file - package org.infinispan.persistence.file
Simple filesystem-based CacheStore implementation.
org.infinispan.persistence.jdbc - package org.infinispan.persistence.jdbc
This package contains a AdvancedLoadWriteStore implementation based on a JDBC database connection.
org.infinispan.persistence.jdbc.binary - package org.infinispan.persistence.jdbc.binary
This JDBC CacheStore implementation is optimized for storing binary (non-String) keys in the cache.
org.infinispan.persistence.jdbc.configuration - package org.infinispan.persistence.jdbc.configuration
 
org.infinispan.persistence.jdbc.connectionfactory - package org.infinispan.persistence.jdbc.connectionfactory
Connection factories for use with the JDBC Cache Store.
org.infinispan.persistence.jdbc.logging - package org.infinispan.persistence.jdbc.logging
 
org.infinispan.persistence.jdbc.mixed - package org.infinispan.persistence.jdbc.mixed
This is a delegating CacheStore implementation that delegates either to a binary or String based JDBC cache store depending on the key used.
org.infinispan.persistence.jdbc.stringbased - package org.infinispan.persistence.jdbc.stringbased
This JDBC CacheStore implementation is optimized for storing String keys in the cache.
org.infinispan.persistence.keymappers - package org.infinispan.persistence.keymappers
 
org.infinispan.persistence.manager - package org.infinispan.persistence.manager
 
org.infinispan.persistence.modifications - package org.infinispan.persistence.modifications
Modifications that are used to encapsulate cache operations for application to a CacheStore.
org.infinispan.persistence.remote - package org.infinispan.persistence.remote
 
org.infinispan.persistence.remote.configuration - package org.infinispan.persistence.remote.configuration
 
org.infinispan.persistence.remote.logging - package org.infinispan.persistence.remote.logging
 
org.infinispan.persistence.remote.wrapper - package org.infinispan.persistence.remote.wrapper
 
org.infinispan.persistence.spi - package org.infinispan.persistence.spi
 
org.infinispan.persistence.support - package org.infinispan.persistence.support
 
org.infinispan.query - package org.infinispan.query
 
org.infinispan.query.backend - package org.infinispan.query.backend
 
org.infinispan.query.clustered - package org.infinispan.query.clustered
 
org.infinispan.query.clustered.commandworkers - package org.infinispan.query.clustered.commandworkers
 
org.infinispan.query.dsl - package org.infinispan.query.dsl
A DSL for querying an Infinispan Cache.
org.infinispan.query.dsl.embedded - package org.infinispan.query.dsl.embedded
 
org.infinispan.query.dsl.embedded.impl - package org.infinispan.query.dsl.embedded.impl
 
org.infinispan.query.dsl.impl - package org.infinispan.query.dsl.impl
 
org.infinispan.query.impl - package org.infinispan.query.impl
 
org.infinispan.query.impl.massindex - package org.infinispan.query.impl.massindex
 
org.infinispan.query.indexmanager - package org.infinispan.query.indexmanager
 
org.infinispan.query.logging - package org.infinispan.query.logging
 
org.infinispan.query.remote.client - package org.infinispan.query.remote.client
 
org.infinispan.query.spi - package org.infinispan.query.spi
 
org.infinispan.registry - package org.infinispan.registry
 
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.tasks - package org.infinispan.tasks
 
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.totalorder - package org.infinispan.transaction.totalorder
 
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.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.commons.util
 
OsgiFileLookup() - Constructor for class org.infinispan.commons.util.OsgiFileLookup
 
OutboundTransferTask - Class in org.infinispan.statetransfer
Outbound state transfer task.
OutboundTransferTask(Address, Set<Integer>, int, int, ConsistentHash, StateProviderImpl, DataContainer, PersistenceManager, RpcManager, CommandsFactory, InternalEntryFactory, 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
 
OutputStream(OutputStream) - Constructor for class org.infinispan.commons.util.Base64.OutputStream
Constructs a Base64.OutputStream in ENCODE mode.
OutputStream(OutputStream, int) - Constructor for class org.infinispan.commons.util.Base64.OutputStream
Constructs a Base64.OutputStream in either ENCODE or DECODE mode.
overrideSegmentReadLocker(SegmentReadLocker) - Method in interface org.infinispan.lucene.directory.BuildContext
Overrides the default SegmentReadLocker.
overrideSegmentReadLocker(SegmentReadLocker) - Method in class org.infinispan.lucene.impl.DirectoryBuilderImpl
 
overrideWriteLocker(LockFactory) - Method in interface org.infinispan.lucene.directory.BuildContext
Overrides the IndexWriter LockFactory
overrideWriteLocker(LockFactory) - Method in class org.infinispan.lucene.impl.DirectoryBuilderImpl
 
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(ConsistentHash, List<Address>) - Constructor for class org.infinispan.distribution.ch.OwnershipStatistics
 
OwnershipStatistics(OwnershipStatistics) - Constructor for class org.infinispan.distribution.ch.OwnershipStatistics
 
ownsData() - Method in interface org.infinispan.statetransfer.StateConsumer
 
ownsData() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
ownsData() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
ownsData() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
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.commons.util.Util
 
Parameter - Class in org.infinispan.cli.commands
 
Parameter(String, int) - Constructor for class org.infinispan.cli.commands.Parameter
 
Parameter - Annotation Type in org.infinispan.jmx.annotations
 
parse(InputStream) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parse(InputStream, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parse(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parseAsyncStore(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser60
 
parseAsyncStore(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
 
parseCommonLoaderAttributes(XMLExtendedStreamReader, int, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
This method is public static so that it can be reused by custom cache store/loader configuration parsers
parseCommonLoaderChildren(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser60
 
parseCommonStoreAttributes(XMLExtendedStreamReader, StoreConfigurationBuilder, String, String, int) - Static method in class org.infinispan.configuration.parsing.Parser60
This method is public static so that it can be reused by custom cache store/loader configuration parsers
parseCommonStoreAttributes(XMLExtendedStreamReader, int, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
This method is public static so that it can be reused by custom cache store/loader configuration parsers
parseCommonStoreChildren(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser60
 
parseCommonStoreChildren(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
 
ParsedCacheMode - Enum in org.infinispan.configuration.parsing
 
parseElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.NamespaceMappingParser
Recursively parses the current element of an XML stream using an appropriate ConfigurationParser depending on the element's namespace.
parseElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parseErrorServerAddress(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
parseErrorServerAddress(String) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
parseErrorServerAddress$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
parseFile(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parseProperties(XMLExtendedStreamReader) - Static method in class org.infinispan.configuration.parsing.Parser60
 
parseProperties(XMLExtendedStreamReader) - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
 
Parser60 - Class in org.infinispan.configuration.parsing
This class implements the parser for 6.0 schema files
Parser60() - Constructor for class org.infinispan.configuration.parsing.Parser60
 
ParserContext - Interface in org.infinispan.configuration.parsing
ParserContext.
ParserContextListener - Interface in org.infinispan.configuration.parsing
ParserContextListener.
parserDoesNotDeclareNamespaces(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
parserDoesNotDeclareNamespaces(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
parserDoesNotDeclareNamespaces(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
parserDoesNotDeclareNamespaces(String) - Method in class org.infinispan.query.logging.Log_$logger
 
parserDoesNotDeclareNamespaces(String) - Method in interface org.infinispan.util.logging.Log
 
parserDoesNotDeclareNamespaces(String) - Method in class org.infinispan.util.logging.Log_$logger
 
parserDoesNotDeclareNamespaces$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
parserDoesNotDeclareNamespaces$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
parserDoesNotDeclareNamespaces$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
parserDoesNotDeclareNamespaces$str() - Method in class org.infinispan.query.logging.Log_$logger
 
parserDoesNotDeclareNamespaces$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 is a namespace-mapping-aware meta-parser which provides a way to delegate the parsing of multi-namespace XML files to appropriate parsers, defined by the ConfigurationParser interface.
ParserRegistry() - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
 
ParserRegistry(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
 
parserRootElementAlreadyRegistered(QName) - Method in class org.infinispan.lucene.logging.Log_$logger
 
parserRootElementAlreadyRegistered(QName) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
parserRootElementAlreadyRegistered(QName) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
parserRootElementAlreadyRegistered(QName) - Method in class org.infinispan.query.logging.Log_$logger
 
parserRootElementAlreadyRegistered(QName) - Method in interface org.infinispan.util.logging.Log
 
parserRootElementAlreadyRegistered(QName) - Method in class org.infinispan.util.logging.Log_$logger
 
parserRootElementAlreadyRegistered$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
parserRootElementAlreadyRegistered$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
parserRootElementAlreadyRegistered$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
parserRootElementAlreadyRegistered$str() - Method in class org.infinispan.query.logging.Log_$logger
 
parserRootElementAlreadyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
parseSingletonStore(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser60
 
parseSingletonStore(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
 
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 class org.infinispan.lucene.logging.Log_$logger
 
passivatedEntries(int, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
passivatedEntries(int, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
passivatedEntries(int, String) - Method in class org.infinispan.query.logging.Log_$logger
 
passivatedEntries(int, String) - Method in interface org.infinispan.util.logging.Log
 
passivatedEntries(int, String) - Method in class org.infinispan.util.logging.Log_$logger
 
passivatedEntries$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
passivatedEntries$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
passivatedEntries$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
passivatedEntries$str() - Method in class org.infinispan.query.logging.Log_$logger
 
passivatedEntries$str() - Method in class org.infinispan.util.logging.Log_$logger
 
passivateObject(SocketAddress, TcpTransport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
passivatingAllEntries() - Method in class org.infinispan.lucene.logging.Log_$logger
 
passivatingAllEntries() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
passivatingAllEntries() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
passivatingAllEntries() - Method in class org.infinispan.query.logging.Log_$logger
 
passivatingAllEntries() - Method in interface org.infinispan.util.logging.Log
 
passivatingAllEntries() - Method in class org.infinispan.util.logging.Log_$logger
 
passivatingAllEntries$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
passivatingAllEntries$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
passivatingAllEntries$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
passivatingAllEntries$str() - Method in class org.infinispan.query.logging.Log_$logger
 
passivatingAllEntries$str() - Method in class org.infinispan.util.logging.Log_$logger
 
passivation() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
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.PersistenceConfigurationBuilder
 
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 class org.infinispan.lucene.logging.Log_$logger
 
passivationWithoutEviction() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
passivationWithoutEviction() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
passivationWithoutEviction() - Method in class org.infinispan.query.logging.Log_$logger
 
passivationWithoutEviction() - Method in interface org.infinispan.util.logging.Log
 
passivationWithoutEviction() - Method in class org.infinispan.util.logging.Log_$logger
 
passivationWithoutEviction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
passivationWithoutEviction$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
passivationWithoutEviction$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
passivationWithoutEviction$str() - Method in class org.infinispan.query.logging.Log_$logger
 
passivationWithoutEviction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
password - Variable in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
password() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
password(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
password() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
 
password(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
PATH - Static variable in class org.infinispan.commons.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.commons.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.
PER_CACHE_COMPONENT_NAMES - Static variable in class org.infinispan.factories.KnownComponentNames
 
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.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.query.clustered.ClusteredQueryCommand
Invokes a query on a (remote) cache and returns results (list of keys).
perform(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQCreateEagerQuery
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQCreateLazyQuery
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQGetResultSize
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQKillLazyIterator
 
perform() - Method in class org.infinispan.query.clustered.commandworkers.CQLazyFetcher
 
perform(InvocationContext) - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
performCommandWithL1WriteIfAble(InvocationContext, DataCommand, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
performL1Lookup(InvocationContext, boolean, Object, DataCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
performLocalWriteSkewCheck(DataContainer, boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
performTotalOrderWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, DataContainer, VersionGenerator, TxInvocationContext, WriteSkewHelper.KeySpecificLogic) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
performWriteSkewCheck(DataContainer, TxInvocationContext, EntryVersion, VersionGenerator) - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
performWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, DataContainer, VersionGenerator, TxInvocationContext, WriteSkewHelper.KeySpecificLogic) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
persistence() - Method in class org.infinispan.configuration.cache.Configuration
 
persistence() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
persistence() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
persistence() - Method in interface org.infinispan.configuration.cache.PersistenceConfigurationChildBuilder
 
PERSISTENCE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
PersistenceConfiguration - Class in org.infinispan.configuration.cache
Configuration for stores.
PersistenceConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration for cache stores.
PersistenceConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
PersistenceConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
PersistenceException - Exception in org.infinispan.persistence.spi
An exception thrown by a CacheLoader or a CacheWriter implementation if there are problems reading from a loader.
PersistenceException() - Constructor for exception org.infinispan.persistence.spi.PersistenceException
 
PersistenceException(String) - Constructor for exception org.infinispan.persistence.spi.PersistenceException
 
PersistenceException(String, Throwable) - Constructor for exception org.infinispan.persistence.spi.PersistenceException
 
PersistenceException(Throwable) - Constructor for exception org.infinispan.persistence.spi.PersistenceException
 
persistenceExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
persistenceExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
persistenceExecutor() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
persistenceManager - Variable in class org.infinispan.interceptors.CacheLoaderInterceptor
 
persistenceManager - Variable in class org.infinispan.interceptors.CacheWriterInterceptor
 
PersistenceManager - Interface in org.infinispan.persistence.manager
Defines the logic for interacting with the chain of external storage.
PersistenceManagerImpl - Class in org.infinispan.persistence.manager
 
PersistenceManagerImpl() - Constructor for class org.infinispan.persistence.manager.PersistenceManagerImpl
 
PersistenceUtil - Class in org.infinispan.persistence
 
PersistenceUtil() - Constructor for class org.infinispan.persistence.PersistenceUtil
 
persistenceWithoutCacheLoaderInterceptor() - Method in class org.infinispan.lucene.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor() - Method in class org.infinispan.query.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor() - Method in interface org.infinispan.util.logging.Log
 
persistenceWithoutCacheLoaderInterceptor() - Method in class org.infinispan.util.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor$str() - Method in class org.infinispan.query.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in class org.infinispan.lucene.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in class org.infinispan.query.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in interface org.infinispan.util.logging.Log
 
persistenceWithoutCacheWriteInterceptor() - Method in class org.infinispan.util.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor$str() - Method in class org.infinispan.query.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
Ping - Class in org.infinispan.cli.commands.server
 
Ping() - Constructor for class org.infinispan.cli.commands.server.Ping
 
ping() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
PING_ON_STARTUP - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PING_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PING_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
pingOnStartup(boolean) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
pingOnStartup() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
pingOnStartup(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
pingOnStartup(boolean) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
If true, a ping request is sent to a back end server in order to fetch cluster's topology.
pingOnStartup(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
pingOnStartup() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
pingOnStartup(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
pingOnStartup(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
If true, a ping request is sent to a back end server in order to fetch cluster's topology.
PingOperation - Class in org.infinispan.client.hotrod.impl.operations
Corresponds to the "ping" operation as defined in Hot Rod protocol specification.
PingOperation(Codec, AtomicInteger, Transport) - Constructor for class org.infinispan.client.hotrod.impl.operations.PingOperation
 
PingOperation(Codec, AtomicInteger, Transport, byte[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.PingOperation
 
PingOperation.PingResult - Enum in org.infinispan.client.hotrod.impl.operations
 
PlatformMBeanServerLookup - Class in org.infinispan.jmx
Default implementation for MBeanServerLookup, will return the platform MBean server.
PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
 
poll() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
poll(long, TimeUnit) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
poll() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
poll(long, TimeUnit) - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
pollNextLocalTask() - Static method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollTask() - Static method in class org.infinispan.commons.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.
PooledConnectionFactory - Class in org.infinispan.persistence.jdbc.connectionfactory
Pooled connection factory based on C3P0.
PooledConnectionFactory() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory
 
PooledConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
PooledConnectionFactoryConfiguration(String, String, String, String) - Constructor for class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
PooledConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
PooledConnectionFactoryConfigurationBuilder.
PooledConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
popNDC(boolean) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
popNDC(boolean) - Static method in class org.infinispan.commons.logging.BasicLogFactory
 
popNDC(boolean) - Static method in class org.infinispan.commons.logging.LogFactory
 
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 - Variable in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
port() - Method in class org.infinispan.client.hotrod.configuration.ServerConfiguration
 
port(int) - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
port() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
 
port(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
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() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
preload - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
preload(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
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.AbstractStoreConfigurationChildBuilder
 
preload() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
Loops through all individual cache loader configs and checks if preload is set on any of them
preload() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
 
preload(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
preload() - Method in interface org.infinispan.persistence.manager.PersistenceManager
Loads the data from the external store into memory during cache startup.
preload() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
preloadNeededIfPersistenceIsEnabledForMetadataCache(String, String) - Method in interface org.infinispan.lucene.logging.Log
 
preloadNeededIfPersistenceIsEnabledForMetadataCache(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
preloadNeededIfPersistenceIsEnabledForMetadataCache$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
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.
PrepareCommand - Class in org.infinispan.commands.tx
Command corresponding to the 1st phase of 2PC.
PrepareCommand(String, GlobalTransaction, boolean, WriteCommand...) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(String, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(String) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
prepared() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
mark the transaction as prepared (the validation was finished) and notify a possible pending commit or rollback command
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in class org.infinispan.lucene.logging.Log_$logger
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in class org.infinispan.query.logging.Log_$logger
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in interface org.infinispan.util.logging.Log
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
preparedTxAlreadyExists$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
preparedTxAlreadyExists$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
preparedTxAlreadyExists$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
preparedTxAlreadyExists$str() - Method in class org.infinispan.query.logging.Log_$logger
 
preparedTxAlreadyExists$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
prepareOnAffectedNodes(TxInvocationContext, PrepareCommand, Collection<Address>, boolean) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
 
prepareOnAffectedNodes(TxInvocationContext, PrepareCommand, Collection<Address>, boolean) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
preparing() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
mark the transaction as preparing, blocking the commit and rollback commands until the TotalOrderRemoteTransactionState.prepared() is invoked
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.commons.util.Util
 
prettyPrintTime(long) - Static method in class org.infinispan.commons.util.Util
Prints a time for display
PrimaryOwnerFilter - Class in org.infinispan.persistence
 
PrimaryOwnerFilter(ClusteringDependentLogic) - Constructor for class org.infinispan.persistence.PrimaryOwnerFilter
 
printArray(byte[], boolean) - Static method in class org.infinispan.commons.util.Util
 
printDebugStats() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
printFullVersionInformation() - Static method in class org.infinispan.Version
Prints full version information to the standard output.
println(String) - Method in interface org.infinispan.cli.Context
 
println(String) - Method in class org.infinispan.cli.impl.ContextImpl
 
println(String) - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
println(String) - Method in interface org.infinispan.cli.io.IOAdapter
 
println(String) - Method in class org.infinispan.cli.io.StreamIOAdapter
 
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
 
printStatusMessage(long, long) - Method in class org.infinispan.query.impl.massindex.DefaultMassIndexerProgressMonitor
 
printVersion() - Static method in class org.infinispan.Version
Returns version information as a string.
printVersionId(byte[], int) - Static method in class org.infinispan.Version
 
PrioritizedMethodMetadata(String, int) - Constructor for class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
problemApplyingStateForKey(String, Object, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemApplyingStateForKey(String, Object, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemApplyingStateForKey(String, Object, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemApplyingStateForKey(String, Object, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
problemApplyingStateForKey(String, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
problemApplyingStateForKey(String, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
problemApplyingStateForKey$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemApplyingStateForKey$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemApplyingStateForKey$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemApplyingStateForKey$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemApplyingStateForKey$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemClosingChannel(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemClosingChannel(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemClosingChannel(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemClosingChannel(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
problemClosingChannel(Exception) - Method in interface org.infinispan.util.logging.Log
 
problemClosingChannel(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
problemClosingChannel$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemClosingChannel$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemClosingChannel$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemClosingChannel$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemClosingChannel$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemPurgingExpired(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemPurgingExpired(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemPurgingExpired(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemPurgingExpired(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
problemPurgingExpired(Exception) - Method in interface org.infinispan.util.logging.Log
 
problemPurgingExpired(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
problemPurgingExpired$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemPurgingExpired$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemPurgingExpired$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemPurgingExpired$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemPurgingExpired$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemsCreatingDirectory(File) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsCreatingDirectory(File) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsCreatingDirectory(File) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsCreatingDirectory(File) - Method in class org.infinispan.query.logging.Log_$logger
 
problemsCreatingDirectory(File) - Method in interface org.infinispan.util.logging.Log
 
problemsCreatingDirectory(File) - Method in class org.infinispan.util.logging.Log_$logger
 
problemsCreatingDirectory$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsCreatingDirectory$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsCreatingDirectory$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsCreatingDirectory$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemsCreatingDirectory$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemsPurgingFile(File, PersistenceException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsPurgingFile(File, PersistenceException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsPurgingFile(File, PersistenceException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsPurgingFile(File, PersistenceException) - Method in class org.infinispan.query.logging.Log_$logger
 
problemsPurgingFile(File, PersistenceException) - Method in interface org.infinispan.util.logging.Log
 
problemsPurgingFile(File, PersistenceException) - Method in class org.infinispan.util.logging.Log_$logger
 
problemsPurgingFile$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsPurgingFile$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsPurgingFile$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsPurgingFile$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemsPurgingFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemsRemovingFile(File) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsRemovingFile(File) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsRemovingFile(File) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsRemovingFile(File) - Method in class org.infinispan.query.logging.Log_$logger
 
problemsRemovingFile(File) - Method in interface org.infinispan.util.logging.Log
 
problemsRemovingFile(File) - Method in class org.infinispan.util.logging.Log_$logger
 
problemsRemovingFile$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsRemovingFile$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsRemovingFile$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsRemovingFile$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemsRemovingFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in interface org.infinispan.util.logging.Log
 
problemsUnregisteringMBeans(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
problemsUnregisteringMBeans$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
problemsUnregisteringMBeans$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
problemsUnregisteringMBeans$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
problemsUnregisteringMBeans$str() - Method in class org.infinispan.query.logging.Log_$logger
 
problemsUnregisteringMBeans$str() - Method in class org.infinispan.util.logging.Log_$logger
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.persistence.file.SingleFileStore
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
process(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean) - Method in class org.infinispan.persistence.remote.RemoteStore
 
process(AdvancedCacheLoader.KeyFilter<K>, AdvancedCacheLoader.CacheLoaderTask<K, V>, Executor, boolean, boolean) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Iterates in parallel over the entries in the storage using the threads from the executor pool.
ProcessedCommand - Class in org.infinispan.cli.commands
 
ProcessedCommand(String) - Constructor for class org.infinispan.cli.commands.ProcessedCommand
 
ProcessedCommand(String, int) - Constructor for class org.infinispan.cli.commands.ProcessedCommand
 
processEntry(MarshalledEntry, AdvancedCacheLoader.TaskContext) - Method in class org.infinispan.distexec.mapreduce.MapReduceCacheLoaderTask
 
processEntry(MarshalledEntry<K, V>, AdvancedCacheLoader.TaskContext) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.CacheLoaderTask
 
processEviction() - Method in interface org.infinispan.eviction.EvictionManager
Processes the eviction event queue.
processEviction() - Method in class org.infinispan.eviction.EvictionManagerImpl
 
processFiltered(File, List<String>) - Method in class org.infinispan.checkstyle.filters.HeadersNoCopyrightCheck
 
processOnAllStores(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, boolean, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
processOnAllStores(AdvancedCacheLoader.KeyFilter, AdvancedCacheLoader.CacheLoaderTask, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
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
 
processRetVal(Object, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
processVisitableCommand(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
 
ProgrammaticSearchMappingProvider - Interface in org.infinispan.query.spi
 
PROJECT_NAME - Static variable in class org.infinispan.Version
 
projection(String...) - Method in interface org.infinispan.query.CacheQuery
Defines the Lucene field names projected and returned in a query result Each field is converted back to it's object representation, an Object[] being returned for each "row"

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

projection - Variable in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
projection(String...) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
ProjectionConstants - Interface in org.infinispan.query
 
ProjectionConverter - Class in org.infinispan.query.impl
Converts between Infinispan and HSearch projection fields.
ProjectionConverter(String[], AdvancedCache<?, ?>, KeyTransformationHandler) - Constructor for class org.infinispan.query.impl.ProjectionConverter
 
ProjectionLoader - Class in org.infinispan.query.impl
 
ProjectionLoader(ProjectionConverter, EntityLoader) - Constructor for class org.infinispan.query.impl.ProjectionLoader
 
Prompt - Class in org.infinispan.cli.shell
 
Prompt() - Constructor for class org.infinispan.cli.shell.Prompt
 
promptExpressionParser(Shell, String) - Static method in class org.infinispan.cli.shell.Prompt
 
propagateCompletion() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Equivalent to CountedCompleter.tryComplete() but does not invoke CountedCompleter.onCompletion(org.infinispan.commons.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() - Method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
properties() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
properties - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
properties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
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 interface org.infinispan.configuration.cache.StoreConfiguration
 
properties() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
properties() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
propertyCouldNotBeReplaced(String) - Method in interface org.infinispan.commons.logging.Log
 
propertyCouldNotBeReplaced(String) - Method in class org.infinispan.commons.logging.Log_$logger
 
propertyCouldNotBeReplaced(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
propertyCouldNotBeReplaced(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
propertyCouldNotBeReplaced(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
propertyCouldNotBeReplaced(String) - Method in class org.infinispan.query.logging.Log_$logger
 
propertyCouldNotBeReplaced(String) - Method in interface org.infinispan.util.logging.Log
 
propertyCouldNotBeReplaced(String) - Method in class org.infinispan.util.logging.Log_$logger
 
propertyCouldNotBeReplaced$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
propertyCouldNotBeReplaced$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
propertyCouldNotBeReplaced$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
propertyCouldNotBeReplaced$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
propertyCouldNotBeReplaced$str() - Method in class org.infinispan.query.logging.Log_$logger
 
propertyCouldNotBeReplaced$str() - Method in class org.infinispan.util.logging.Log_$logger
 
PropertyFormatter - Class in org.infinispan.configuration.format
Extracts the configuration into flat key-value property structure by reflection.
PropertyFormatter() - Constructor for class org.infinispan.configuration.format.PropertyFormatter
Create a new PropertyFormatter instance.
PropertyFormatter(String, String) - Constructor for class org.infinispan.configuration.format.PropertyFormatter
Create a new PropertyFormatter instance.
props - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
PropsKeyedObjectPoolFactory<K,V> - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
PropsKeyedObjectPoolFactory(KeyedPoolableObjectFactory<K, V>, ConnectionPoolConfiguration) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.PropsKeyedObjectPoolFactory
 
PROTOCOL_VERSION - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PROTOCOL_VERSION_10 - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PROTOCOL_VERSION_11 - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
PROTOCOL_VERSION_12 - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
protocolVersion(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
protocolVersion() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
protocolVersion(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
protocolVersion(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
This property defines the protocol version that this client should use.
protocolVersion(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
protocolVersion() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
protocolVersion(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
protocolVersion(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
This property defines the protocol version that this client should use.
ProtoStreamMarshaller - Class in org.infinispan.client.hotrod.marshall
 
ProtoStreamMarshaller() - Constructor for class org.infinispan.client.hotrod.marshall.ProtoStreamMarshaller
 
Proxies - Class in org.infinispan.commons.util
Proxies is a collection of useful dynamic profixes.
Proxies() - Constructor for class org.infinispan.commons.util.Proxies
 
pruneInvalidMembers(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.file.SingleFileStore
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.remote.RemoteStore
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter
Using the thread in the pool, removed all the expired data from the persistence storage.
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
 
purgeAllIndexes() - Method in class org.infinispan.query.backend.QueryInterceptor
Remove all entries from all known indexes
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 interface org.infinispan.persistence.manager.PersistenceManager
Removes the expired entries from all the existing storage.
purgeExpired() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
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.StoreConfiguration
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.
purgeStaleEntries() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Removes any stale entries whose keys have been finalized.
purgingExpiredEntriesFailed(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
purgingExpiredEntriesFailed(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
purgingExpiredEntriesFailed(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
purgingExpiredEntriesFailed(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
purgingExpiredEntriesFailed(Throwable) - Method in interface org.infinispan.util.logging.Log
 
purgingExpiredEntriesFailed(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
purgingExpiredEntriesFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
purgingExpiredEntriesFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
purgingExpiredEntriesFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
purgingExpiredEntriesFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
purgingExpiredEntriesFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
pushNDC(String, boolean) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
pushNDC(String, boolean) - Static method in class org.infinispan.commons.logging.BasicLogFactory
 
pushNDC(String, boolean) - Static method in class org.infinispan.commons.logging.LogFactory
 
pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
pushReadInterruptionDueToCacheManagerShutdown(int, InterruptedException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown(int, InterruptedException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown(int, InterruptedException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown(int, InterruptedException) - Method in class org.infinispan.query.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown(int, InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
pushReadInterruptionDueToCacheManagerShutdown(int, InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown$str() - Method in class org.infinispan.query.logging.Log_$logger
 
pushReadInterruptionDueToCacheManagerShutdown$str() - Method in class org.infinispan.util.logging.Log_$logger
 
pushState(Cache) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
PushStateException(String, Throwable) - Constructor for exception org.infinispan.persistence.support.SingletonCacheWriter.PushStateException
 
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.
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.
put(K, V, Metadata) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
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, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #put(K, V), which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
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) - Method in class org.infinispan.CacheImpl
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
put(K, V, Metadata) - 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 - Class in org.infinispan.cli.commands.server
 
Put() - Constructor for class org.infinispan.cli.commands.server.Put
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
put(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
put(K, V) - Method in interface org.infinispan.commons.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.commons.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.commons.api.BasicCache
An overloaded form of BasicCache.put(Object, Object), which takes in lifespan parameters.
put(K, V) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
put(K, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Maps the specified key to the specified value in this table.
put(K, V) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Maps the specified key to the specified value in this table.
put(K, V) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
put(K, V) - Method in class org.infinispan.commons.util.WeakValueHashMap
 
put(Object, Object, Metadata) - Method in interface org.infinispan.container.DataContainer
Puts an entry in the cache along with metadata adding information such lifespan of entry, max idle time, version information...etc.
put(Object, Object, Metadata) - 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, Metadata) - Method in class org.infinispan.DecoratedCache
 
put(UUID, DocumentExtractor) - Method in class org.infinispan.query.clustered.QueryBox
Register a query (DocumentExtractor), so we can lazily load the results.
put(S, K, V) - Method in interface org.infinispan.registry.ClusterRegistry
 
put(S, K, V) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
put(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Maps the specified key to the specified value in this table.
PUT_IF_ABSENT_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_IF_ABSENT_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
PUT_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - 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) - Method in class org.infinispan.CacheImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.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.commons.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.commons.equivalence.EquivalentHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
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.
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
Deprecated.
Asynchronous version of Map.putAll(Map).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
Synthetic operation.
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #putAll(Map).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #putAll(Map, long, TimeUnit).
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #putAll(Map, long, TimeUnit, long, TimeUnit).
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, Metadata) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
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, Metadata) - Method in interface org.infinispan.AdvancedCache
Asynchronous version of AdvancedCache.put(Object, Object, Metadata) which stores metadata alongside the value.
putAsync(K, V) - Method in interface org.infinispan.api.BasicCache
Deprecated.
Asynchronous version of BasicCache.put(Object, Object).
putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putAsync(K, V) - Method in class org.infinispan.CacheImpl
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putAsync(K, V, Metadata) - Method in class org.infinispan.CacheImpl
 
putAsync(K, V) - Method in class org.infinispan.CacheSupport
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putAsync(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #put(Object, Object).
putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #put(Object, Object, long, TimeUnit) .
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #put(Object, Object, long, TimeUnit, long, TimeUnit).
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
 
putAsync(K, V, Metadata) - 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, Metadata) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
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, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #putIfAbsent(K, V), which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.CacheImpl
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putIfAbsent(K, V, Metadata) - 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, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.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.commons.api.BasicCache
An overloaded form of ConcurrentMap.putIfAbsent(Object, Object), which takes in lifespan parameters.
putIfAbsent(K, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
putIfAbsent(K, V) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, Metadata) - Method in class org.infinispan.DecoratedCache
 
putIfAbsent(K, V) - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
putIfAbsentAsync(K, V) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.AbstractDelegatingCache
 
putIfAbsentAsync(K, V) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
putIfAbsentAsync(K, V) - Method in class org.infinispan.CacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
putIfAbsentAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #putIfAbsent(Object, Object).
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #putIfAbsent(Object, Object, long, TimeUnit) .
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit).
putIfAbsentAsync(K, V) - Method in class org.infinispan.DecoratedCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.DecoratedCache
 
PutIfAbsentOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "putIfAbsent" operation as described in Hot Rod protocol specification.
PutIfAbsentOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.PutIfAbsentOperation
 
PutKeyValueCommand - Class in org.infinispan.commands.write
Implements functionality defined by BasicCache.put(Object, Object)
PutKeyValueCommand() - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
PutKeyValueCommand(Object, Object, boolean, CacheNotifier, Metadata, Set<Flag>, Equivalence) - 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, Metadata, Set<Flag>) - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutOperation<K,V> - Class in org.infinispan.atomic
An atomic put operation.
PutOperation() - Constructor for class org.infinispan.atomic.PutOperation
 
PutOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "put" as defined by Hot Rod protocol specification.
PutOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.PutOperation
 
PutOperation.Externalizer - Class in org.infinispan.atomic
 

Q

queriedAttributeNotFound(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
queriedAttributeNotFound(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
queriedAttributeNotFound(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
queriedAttributeNotFound(String) - Method in class org.infinispan.query.logging.Log_$logger
 
queriedAttributeNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
queriedAttributeNotFound(String) - Method in class org.infinispan.util.logging.Log_$logger
 
queriedAttributeNotFound$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
queriedAttributeNotFound$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
queriedAttributeNotFound$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
queriedAttributeNotFound$str() - Method in class org.infinispan.query.logging.Log_$logger
 
queriedAttributeNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
query - Variable in class org.infinispan.query.clustered.commandworkers.ClusteredQueryCommandWorker
 
Query - Interface in org.infinispan.query.dsl
An immutable object representing both the query and the result.
QUERY_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
QUERY_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
QueryBox - Class in org.infinispan.query.clustered
Each node in the cluster has a QueryBox instance.
QueryBox() - Constructor for class org.infinispan.query.clustered.QueryBox
 
QueryBuilder<T extends Query> - Interface in org.infinispan.query.dsl
A builder for Query objects.
QueryExtractorUtil - Class in org.infinispan.query.clustered.commandworkers
QueryExtractorUtil.
QueryFactory<T extends Query> - Interface in org.infinispan.query.dsl
Factory for query DSL objects.
QueryInterceptor - Class in org.infinispan.query.backend
This interceptor will be created when the System Property "infinispan.query.indexLocalOnly" is "false"

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

QueryInterceptor(SearchFactoryIntegrator) - Constructor for class org.infinispan.query.backend.QueryInterceptor
 
QueryMetadataFileFinder - Class in org.infinispan.query.impl
 
QueryMetadataFileFinder() - Constructor for class org.infinispan.query.impl.QueryMetadataFileFinder
 
QueryModuleCommandExtensions - Class in org.infinispan.query.impl
 
QueryModuleCommandExtensions() - Constructor for class org.infinispan.query.impl.QueryModuleCommandExtensions
 
QueryOperation - Class in org.infinispan.client.hotrod.impl.operations
 
QueryOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[], RemoteQuery) - Constructor for class org.infinispan.client.hotrod.impl.operations.QueryOperation
 
QueryRequest - Class in org.infinispan.query.remote.client
 
QueryRequest() - Constructor for class org.infinispan.query.remote.client.QueryRequest
 
QueryRequest.SortCriteria - Class in org.infinispan.query.remote.client
 
QueryRequestMarshaller - Class in org.infinispan.query.remote.client
 
QueryRequestMarshaller() - Constructor for class org.infinispan.query.remote.client.QueryRequestMarshaller
 
QueryResponse - Class in org.infinispan.query.clustered
QueryResponse.
QueryResponse(Object) - Constructor for class org.infinispan.query.clustered.QueryResponse
 
QueryResponse(int) - Constructor for class org.infinispan.query.clustered.QueryResponse
 
QueryResponse(TopDocs, UUID, int) - Constructor for class org.infinispan.query.clustered.QueryResponse
 
QueryResponse - Class in org.infinispan.query.remote.client
 
QueryResponse() - Constructor for class org.infinispan.query.remote.client.QueryResponse
 
QueryResponseMarshaller - Class in org.infinispan.query.remote.client
 
QueryResponseMarshaller() - Constructor for class org.infinispan.query.remote.client.QueryResponseMarshaller
 
QueryResultLoader - Interface in org.infinispan.query.impl
 
QueueingListener() - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService.QueueingListener
 
quietlyComplete() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Completes this task normally without setting a value.
quietlyCompleteRoot() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Equivalent to getRoot().quietlyComplete().
quietlyInvoke() - Method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.ForkJoinTask
Joins this task, without returning its result or throwing its exception.
Quit - Class in org.infinispan.cli.commands.client
 
Quit() - Constructor for class org.infinispan.cli.commands.client.Quit
 

R

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) - Method in class org.infinispan.lucene.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated(String, String, List) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated(String, String, List) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated(String, String, List) - Method in class org.infinispan.query.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated(String, String, List<String>) - Method in interface org.infinispan.util.logging.Log
 
randomCacheModeSynonymsDeprecated(String, String, List) - Method in class org.infinispan.util.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
randomClusterMembers(List<Address>, int) - Method in class org.infinispan.distexec.DefaultExecutorService
 
RangeConditionContext - Interface in org.infinispan.query.dsl
A context for ranges.
RankCalculator() - Constructor for class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
 
rawValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
rawValues() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
rawValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
rawValues(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Normally the RemoteStore stores values wrapped in InternalCacheEntry.
read(Configuration) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
read(ConnectionPoolConfiguration) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
 
read(ExecutorFactoryConfiguration) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
read(ServerConfiguration) - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
read(SslConfiguration) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
read(T) - Method in interface org.infinispan.commons.configuration.Builder
Reads the configuration from an already created configuration bean into this builder.
read() - Method in class org.infinispan.commons.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.commons.util.Base64.InputStream
Calls Base64.InputStream.read() repeatedly until the end of stream is reached or len bytes are read.
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(ClusteringConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
read(ClusterLoaderConfiguration) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
read(CompatibilityModeConfiguration) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
 
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(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(LockingConfiguration) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
read(PersistenceConfiguration) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
read(RecoveryConfiguration) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
read(SingleFileStoreConfiguration) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
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(LuceneLoaderConfiguration) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
 
read(CLInterfaceLoaderConfiguration) - Method in class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationBuilder
 
read(JdbcBinaryStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
read(JdbcMixedStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
read(JdbcStringBasedStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
read(ManagedConnectionFactoryConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
 
read(PooledConnectionFactoryConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
read(SimpleConnectionFactoryConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
read(TableManipulationConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
read(ConnectionPoolConfiguration) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
read(ExecutorFactoryConfiguration) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
read(RemoteServerConfiguration) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
read(RemoteStoreConfiguration) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
read4ByteInt() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
read4ByteInt() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
ReadableGridFileChannel - Class in org.infinispan.io
 
readArray() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readArray() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
reads an vint which is size; then an array having that size.
readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readBooleanAttribute(Element, String, String, boolean) - Static method in class org.infinispan.configuration.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.configuration.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.configuration.parsing.XmlConfigHelper
Similar to XmlConfigHelper.readStringContents(org.w3c.dom.Element,String) except that it returns a boolean.
readByte() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readByte() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readByte() - Method in class org.infinispan.lucene.impl.SingleChunkIndexInput
 
readByteArray(int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readByteArray(int) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readBytes(byte[], int, int) - Method in class org.infinispan.lucene.impl.SingleChunkIndexInput
 
readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
ReadCommittedEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
ReadCommittedEntry(Object, Object, Metadata) - 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 interface org.infinispan.configuration.parsing.ConfigurationParser
The entry point of a configuration parser which gets passed a XMLExtendedStreamReader positioned at a root element associated with the parser itself according to the registered mapping.
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser60
 
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationParser60
 
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser60
 
readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser60
 
readExternal(Object, ObjectInput) - Method in class org.infinispan.commons.marshall.jboss.JBossExternalizerAdapter
 
readExternal(ObjectInput) - Method in class org.infinispan.commons.util.ImmutableListCopy
readExternal(ObjectInput) - Method in class org.infinispan.io.GridFile.Metadata
 
readExternal(ObjectInput) - Method in class org.infinispan.marshall.core.MarshalledValue
 
readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFrom(MessageMarshaller.ProtoStreamReader) - Method in class org.infinispan.query.remote.client.QueryRequestMarshaller
 
readFrom(MessageMarshaller.ProtoStreamReader) - Method in class org.infinispan.query.remote.client.QueryResponseMarshaller
 
readFrom(MessageMarshaller.ProtoStreamReader) - Method in class org.infinispan.query.remote.client.SortCriteriaMarshaller
 
readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readHeader(Transport, HeaderParams) - Method in interface org.infinispan.client.hotrod.impl.protocol.Codec
Reads a response header from the transport and returns the status of the response.
readHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
readHeaderAndValidate(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
Magic | Message Id | Op code | Status | Topology Change Marker
readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readInternal(AbstractJdbcStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readln(String) - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
readln(String) - Method in interface org.infinispan.cli.io.IOAdapter
 
readln(String) - Method in class org.infinispan.cli.io.StreamIOAdapter
 
readLong() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readLong() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readManagedAttributeAlreadyPresent(Method) - Method in class org.infinispan.lucene.logging.Log_$logger
 
readManagedAttributeAlreadyPresent(Method) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
readManagedAttributeAlreadyPresent(Method) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
readManagedAttributeAlreadyPresent(Method) - Method in class org.infinispan.query.logging.Log_$logger
 
readManagedAttributeAlreadyPresent(Method) - Method in interface org.infinispan.util.logging.Log
 
readManagedAttributeAlreadyPresent(Method) - Method in class org.infinispan.util.logging.Log_$logger
 
readManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
readManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
readManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
readManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.query.logging.Log_$logger
 
readManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.util.logging.Log_$logger
 
readMetadata(URL) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
 
readNewTopologyAndHash(Transport, AtomicInteger) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
readNewTopologyIfPresent(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMap.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.AtomicHashMapDelta.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.ClearOperation.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.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.commons.io.ByteBufferImpl.Externalizer
 
readObject(ObjectInput) - Method in interface org.infinispan.commons.marshall.Externalizer
Read an instance from the stream.
readObject(ObjectInput) - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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.metadata.MetadataImmortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.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.versioning.NumericVersion.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.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.lucene.ChunkCacheKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
readObject(Unmarshaller) - Method in class org.infinispan.marshall.core.ExternalizerTable
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshalledValue.Externalizer
 
readObject(ObjectInput) - Method in interface org.infinispan.marshall.Externalizer
Deprecated.
Read an instance from the stream.
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ArrayExternalizers.ListArray
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ListExternalizer
 
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(ObjectInput) - Method in class org.infinispan.marshall.LegacyAdvancedExternalizerAdapter
Deprecated.
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.LegacyExternalizerAdapter
Deprecated.
 
readObject(ObjectInput) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.metadata.InternalMetadataImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.registry.ScopedKey.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.KeyValuePair.Externalizer
 
ReadOnlyDataContainerBackedKeySet - Class in org.infinispan.util
A Set view of keys in a data container, which is read-only and has efficient contains(), unlike some data container ley sets.
ReadOnlyDataContainerBackedKeySet(DataContainer) - Constructor for class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
readParameters(ObjectInput) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
readPropertiesContents(Element, String) - Static method in class org.infinispan.configuration.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.configuration.parsing.XmlConfigHelper
 
readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readStream(InputStream) - Static method in class org.infinispan.commons.util.Util
Reads the given InputStream fully, closes the stream and returns the result as a byte array.
readString() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readString() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readStringAttributeElement(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Read an element which contains only a single string attribute.
readStringContents(Element, String) - Static method in class org.infinispan.configuration.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.commons.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedInt(InputStream) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
readUnsignedInt(ByteBuffer) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
readUnsignedInt(byte[], int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(ObjectInput) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedLong(InputStream) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
readUnsignedLong(ByteBuffer) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
readUnsignedLong(byte[], int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Reads an int stored in variable-length format.
readUnsignedShort() - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
readUnsignedShort() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readUnsignedShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readUTF() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readVersionsFromResponse(Response, CacheTransaction) - Static method in class org.infinispan.transaction.WriteSkewHelper
 
readVInt() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readVInt() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
readVLong() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
readVLong() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
reaperEnabled() - 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 class org.infinispan.lucene.logging.Log_$logger
 
rebalanceError(String, Address, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
rebalanceError(String, Address, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
rebalanceError(String, Address, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
rebalanceError(String, Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
rebalanceError(String, Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
rebalanceError$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
rebalanceError$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
rebalanceError$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
rebalanceError$str() - Method in class org.infinispan.query.logging.Log_$logger
 
rebalanceError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 class org.infinispan.lucene.logging.Log_$logger
 
rebalanceStartError(String, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
rebalanceStartError(String, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
rebalanceStartError(String, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
rebalanceStartError(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
rebalanceStartError(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
rebalanceStartError$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
rebalanceStartError$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
rebalanceStartError$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
rebalanceStartError$str() - Method in class org.infinispan.query.logging.Log_$logger
 
rebalanceStartError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
recalculateMinTopologyIdIfNeeded(CacheTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
receivedClusterView(View) - Method in class org.infinispan.lucene.logging.Log_$logger
 
receivedClusterView(View) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
receivedClusterView(View) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
receivedClusterView(View) - Method in class org.infinispan.query.logging.Log_$logger
 
receivedClusterView(View) - Method in interface org.infinispan.util.logging.Log
 
receivedClusterView(View) - Method in class org.infinispan.util.logging.Log_$logger
 
receivedClusterView$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
receivedClusterView$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
receivedClusterView$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
receivedClusterView$str() - Method in class org.infinispan.query.logging.Log_$logger
 
receivedClusterView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
receivedMergedView(View) - Method in class org.infinispan.lucene.logging.Log_$logger
 
receivedMergedView(View) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
receivedMergedView(View) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
receivedMergedView(View) - Method in class org.infinispan.query.logging.Log_$logger
 
receivedMergedView(View) - Method in interface org.infinispan.util.logging.Log
 
receivedMergedView(View) - Method in class org.infinispan.util.logging.Log_$logger
 
receivedMergedView$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
receivedMergedView$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
receivedMergedView$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
receivedMergedView$str() - Method in class org.infinispan.query.logging.Log_$logger
 
receivedMergedView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.commons.marshall.AdaptiveBufferSizePredictor
 
recordSize(int) - Method in interface org.infinispan.commons.marshall.BufferSizePredictor
Record the size of the of data in the last buffer used.
recordSize(int) - Method in interface org.infinispan.marshall.BufferSizePredictor
Deprecated.
Record the size of the of data in the last buffer used.
recordSize(int) - Method in class org.infinispan.marshall.BufferSizePredictorAdapter
Deprecated.
 
recordSize(int) - Method in class org.infinispan.marshall.CommonsBufferSizePredictorAdapter
Deprecated.
 
recordSize(int) - Method in class org.infinispan.marshall.LegacyBufferSizePredictorAdapter
Deprecated.
 
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() - 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
 
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
 
RecoveryAwareLocalTransaction - Class in org.infinispan.transaction.xa.recovery
Extends LocalXaTransaction and adds recovery related information.
RecoveryAwareLocalTransaction(Transaction, GlobalTransaction, boolean, int, Equivalence<Object>) - 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, Equivalence<Object>) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
RecoveryAwareRemoteTransaction(GlobalTransaction, int, Equivalence<Object>) - 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 class org.infinispan.lucene.logging.Log_$logger
 
recoveryIgnored() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
recoveryIgnored() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
recoveryIgnored() - Method in class org.infinispan.query.logging.Log_$logger
 
recoveryIgnored() - Method in interface org.infinispan.util.logging.Log
 
recoveryIgnored() - Method in class org.infinispan.util.logging.Log_$logger
 
recoveryIgnored$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
recoveryIgnored$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
recoveryIgnored$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
recoveryIgnored$str() - Method in class org.infinispan.query.logging.Log_$logger
 
recoveryIgnored$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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(long, EquivalentConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>, EquivalentConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating the given transformation of all (key, value) pairs using the given reducer to combine values, or null if none.
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(Object, Iterator<LuceneWork>) - Method in class org.infinispan.query.impl.massindex.IndexingReducer
 
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, EquivalentConcurrentHashMapV8.BiFun<Map.Entry<K, V>, Map.Entry<K, V>, ? extends Map.Entry<K, V>>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating all entries using the given reducer to combine values, or null if none.
reduceEntries(long, EquivalentConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>, EquivalentConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating the given transformation of all entries using the given reducer to combine values, or null if none.
reduceEntriesToDouble(long, EquivalentConcurrentHashMapV8.ObjectToDouble<Map.Entry<K, V>>, double, EquivalentConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectToInt<Map.Entry<K, V>>, int, EquivalentConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectToLong<Map.Entry<K, V>>, long, EquivalentConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.BiFun<? super K, ? super K, ? extends K>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating all keys using the given reducer to combine values, or null if none.
reduceKeys(long, EquivalentConcurrentHashMapV8.Fun<? super K, ? extends U>, EquivalentConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating the given transformation of all keys using the given reducer to combine values, or null if none.
reduceKeysToDouble(long, EquivalentConcurrentHashMapV8.ObjectToDouble<? super K>, double, EquivalentConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectToInt<? super K>, int, EquivalentConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectToLong<? super K>, long, EquivalentConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectByObjectToDouble<? super K, ? super V>, double, EquivalentConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectByObjectToInt<? super K, ? super V>, int, EquivalentConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectByObjectToLong<? super K, ? super V>, long, EquivalentConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.BiFun<? super V, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating all values using the given reducer to combine values, or null if none.
reduceValues(long, EquivalentConcurrentHashMapV8.Fun<? super V, ? extends U>, EquivalentConcurrentHashMapV8.BiFun<? super U, ? super U, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns the result of accumulating the given transformation of all values using the given reducer to combine values, or null if none.
reduceValuesToDouble(long, EquivalentConcurrentHashMapV8.ObjectToDouble<? super V>, double, EquivalentConcurrentHashMapV8.DoubleByDoubleToDouble) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectToInt<? super V>, int, EquivalentConcurrentHashMapV8.IntByIntToInt) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, EquivalentConcurrentHashMapV8.ObjectToLong<? super V>, long, EquivalentConcurrentHashMapV8.LongByLongToLong) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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.commons.util
Basic reflection utilities to enhance what the JDK provides.
ReflectionUtil() - Constructor for class org.infinispan.commons.util.ReflectionUtil
 
refreshProperties() - Method in interface org.infinispan.cli.Context
 
refreshProperties() - Method in class org.infinispan.cli.impl.ContextImpl
 
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
 
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
 
registeringQueryInterceptor() - Method in interface org.infinispan.query.logging.Log
 
registeringQueryInterceptor() - Method in class org.infinispan.query.logging.Log_$logger
 
registeringQueryInterceptor$str() - Method in class org.infinispan.query.logging.Log_$logger
 
registerKeyTransformer(Class<?>, Class<? extends Transformer>) - Method in class org.infinispan.query.backend.QueryInterceptor
 
registerKeyTransformer(Class<?>, Class<? extends Transformer>) - Method in class org.infinispan.query.impl.SearchManagerImpl
 
registerKeyTransformer(Class<?>, Class<? extends Transformer>) - Method in interface org.infinispan.query.spi.SearchManagerImplementor
Registers a Transformer for the supplied key class.
registerL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in interface org.infinispan.distribution.L1Manager
Registers the given write synchronizer to be notified whenever a remote value is looked up for the given key.
registerL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in class org.infinispan.distribution.L1ManagerImpl
 
registerLockedKey(Object) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
registerMarshallers(SerializationContext) - Static method in class org.infinispan.query.remote.client.MarshallerRegistration
 
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.query.backend.TransactionalEventTransactionContext
Registers the synchronization passed in as a parameter with the ongoing transaction.
registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
Register a Synchronization callback with this transaction.
registerTransformer(Class<?>, Class<? extends Transformer>) - Method in class org.infinispan.query.backend.KeyTransformationHandler
Registers a Transformer for the supplied key class.
rehashCommandReceivedOnNonDistributedCache() - Method in class org.infinispan.lucene.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache() - Method in class org.infinispan.query.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache() - Method in interface org.infinispan.util.logging.Log
 
rehashCommandReceivedOnNonDistributedCache() - Method in class org.infinispan.util.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache$str() - Method in class org.infinispan.query.logging.Log_$logger
 
rehashCommandReceivedOnNonDistributedCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
rehashDisabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
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() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated.
rehashRpcTimeout(long) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
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(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
reincarnate() - Method in interface org.infinispan.container.entries.InternalCacheEntry
reincarnate(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
"Reincarnates" an entry.
reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
reinitialize() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
release() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
release() - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
release(TotalOrderRemoteTransactionState) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
Release the locked key possibly unblock waiting prepares.
releaseAllLocks(List<Object>) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Releases locks on all keys passed in.
releaseConnection(Connection) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
Destroys a connection.
releaseConnection(Connection) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ManagedConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory
 
releaseConnection(Connection) - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
releaseExclusiveTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseExclusiveTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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, boolean) - Method in class org.infinispan.transaction.AbstractEnlistmentAdapter
 
releaseSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
releaseTransport(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
releaseTransport(Transport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
releaseTransport(Transport) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
remainingTime(long, TimeUnit) - Method in class org.infinispan.util.DefaultTimeService
 
remainingTime(long, TimeUnit) - Method in interface org.infinispan.util.TimeService
 
REMOTE_COMMAND_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
RemoteCache<K,V> - Interface in org.infinispan.client.hotrod
Provides remote reference to a Hot Rod server/cluster.
remoteCache(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
remoteCache() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
RemoteCacheImpl<K,V> - Class in org.infinispan.client.hotrod.impl
 
RemoteCacheImpl(RemoteCacheManager, String) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
RemoteCacheManager - Class in org.infinispan.client.hotrod
Factory for RemoteCaches.
RemoteCacheManager(Configuration) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Create a new RemoteCacheManager using the supplied Configuration.
RemoteCacheManager(Configuration, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Create a new RemoteCacheManager using the supplied Configuration.
RemoteCacheManager(Marshaller, Properties, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Marshaller, Properties, boolean, ClassLoader, ExecutorFactory) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Marshaller, Properties) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Marshaller, Properties, ExecutorFactory) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Marshaller, Properties, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Properties, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Properties, boolean, ClassLoader, ExecutorFactory) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Properties) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(Properties, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(java.util.Properties), but it will try to lookup the config properties in the classpath, in a file named hotrod-client.properties.
RemoteCacheManager() - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Same as RemoteCacheManager.RemoteCacheManager(boolean) and it also starts the cache.
RemoteCacheManager(String, int, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String, int, boolean, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String, int) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String, int, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String, boolean, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(String, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(URL, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(URL, boolean, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(URL) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManager(URL, ClassLoader) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
Deprecated.
RemoteCacheManagerNotStartedException - Exception in org.infinispan.client.hotrod.exceptions
Thrown when trying to use an RemoteCache that is associated to an RemoteCacheManager that was not started.
RemoteCacheManagerNotStartedException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteCacheManagerNotStartedException
 
remoteCacheName(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
remoteCacheName() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
remoteCacheName(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
remoteCacheName(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
The name of the remote cache in the remote infinispan cluster, to which to connect to.
RemoteCacheSupport<K,V> - Class in org.infinispan.client.hotrod.impl
Purpose: keep all delegating and unsupported methods in one place -> readability.
RemoteCacheSupport() - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
RemoteCacheSupport(long, long) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
remoteCallTimeout() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
 
remoteCallTimeout(long) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
remoteCallTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
remoteCommandsExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
remoteCommandsExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
remoteCommandsExecutor() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
remoteCommandsExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
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(Address, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
remoteException(Address, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
remoteException(Address, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteException(Address, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
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
 
remoteException(Address, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteException$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
remoteException$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
remoteException$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteException$str() - Method in class org.infinispan.query.logging.Log_$logger
 
remoteException$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
remoteExecutionFailed(Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteExecutionFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
remoteExecutionFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
remoteExecutionFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteExecutionFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
remoteExecutionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteGetBeforeWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
remoteGetBeforeWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
remoteGetBeforeWrite(InvocationContext, WriteCommand, BaseDistributionInterceptor.RecipientGenerator) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
remoteLockIntention - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
 
remoteLocksAcquired(Collection<Address>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
RemoteNodeSuspectException - Exception in org.infinispan.client.hotrod.exceptions
When a remote node is suspected and evicted from the cluster while an operation is ongoing, the Hot Rod client emits this exception.
RemoteNodeSuspectException(String, long, short) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteNodeSuspectException
 
RemoteQuery - Class in org.infinispan.client.hotrod.impl.query
 
RemoteQuery(RemoteCacheImpl, SerializationContext, String, List<SortCriteria>, long, int) - Constructor for class org.infinispan.client.hotrod.impl.query.RemoteQuery
 
RemoteQueryBuilder - Class in org.infinispan.client.hotrod.impl.query
 
RemoteQueryBuilder(RemoteCacheImpl, SerializationContext, Class) - Constructor for class org.infinispan.client.hotrod.impl.query.RemoteQueryBuilder
 
RemoteQueryFactory - Class in org.infinispan.client.hotrod.impl.query
 
RemoteQueryFactory(RemoteCacheImpl) - Constructor for class org.infinispan.client.hotrod.impl.query.RemoteQueryFactory
 
RemoteServerConfiguration - Class in org.infinispan.persistence.remote.configuration
 
RemoteServerConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
 
remoteSite(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
remoteSite() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
RemoteStore - Class in org.infinispan.persistence.remote
Cache store that delegates the call to a infinispan cluster.
RemoteStore() - Constructor for class org.infinispan.persistence.remote.RemoteStore
 
RemoteStoreConfiguration - Class in org.infinispan.persistence.remote.configuration
 
RemoteStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, ExecutorFactoryConfiguration, String, ConnectionPoolConfiguration, long, boolean, boolean, int, String, boolean, String, boolean, String, List<RemoteServerConfiguration>, long, boolean, String, int) - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
RemoteStoreConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
RemoteStoreConfigurationBuilder.
RemoteStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
RemoteStoreConfigurationChildBuilder<S> - Interface in org.infinispan.persistence.remote.configuration
 
RemoteStoreConfigurationParser60 - Class in org.infinispan.persistence.remote.configuration
JdbcCacheStoreConfigurationParser60.
RemoteStoreConfigurationParser60() - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser60
 
remoteStoreNoHotRodWrapping(String) - Method in interface org.infinispan.persistence.remote.logging.Log
 
remoteStoreNoHotRodWrapping(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteStoreNoHotRodWrapping$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
RemoteTransaction - Class in org.infinispan.transaction
Defines the state of a remotely originated transaction.
RemoteTransaction(WriteCommand[], GlobalTransaction, int, Equivalence<Object>) - Constructor for class org.infinispan.transaction.RemoteTransaction
 
RemoteTransaction(GlobalTransaction, int, Equivalence<Object>) - Constructor for class org.infinispan.transaction.RemoteTransaction
 
remoteTransactionCommitted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.TransactionTable
Removes the RemoteTransaction corresponding to the given tx.
remoteTransactionCommitted(GlobalTransaction, boolean) - 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 class org.infinispan.lucene.logging.Log_$logger
 
remoteTxAlreadyRegistered() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
remoteTxAlreadyRegistered() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteTxAlreadyRegistered() - Method in class org.infinispan.query.logging.Log_$logger
 
remoteTxAlreadyRegistered() - Method in interface org.infinispan.util.logging.Log
 
remoteTxAlreadyRegistered() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTxAlreadyRegistered$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
remoteTxAlreadyRegistered$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
remoteTxAlreadyRegistered$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
remoteTxAlreadyRegistered$str() - Method in class org.infinispan.query.logging.Log_$logger
 
remoteTxAlreadyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
remoteValueFound(InternalCacheEntry) - Method in class org.infinispan.distribution.L1ManagerImpl
 
remoteValueFound(InternalCacheEntry) - Method in interface org.infinispan.distribution.RemoteValueRetrievedListener
Invoked when a remote value is found from a remote source
RemoteValueRetrievedListener - Interface in org.infinispan.distribution
Listener that is notified when a remote value is looked up
remove(Object, Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMap
 
remove(Object) - Method in class org.infinispan.atomic.AtomicHashMapProxy
 
remove(Object) - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
remove(Object, Object) - Method in class org.infinispan.CacheImpl
 
remove(Object) - Method in class org.infinispan.CacheImpl
 
Remove - Class in org.infinispan.cli.commands.server
 
Remove() - Constructor for class org.infinispan.cli.commands.server.Remove
 
remove(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
remove(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
remove(Object) - 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.commons.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.commons.equivalence.EquivalentHashMap
 
remove(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
 
remove(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Removes the specified element from this set if it is present.
remove(Object) - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
 
remove(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
remove(Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.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.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
remove(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
remove(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
remove(int) - Method in class org.infinispan.commons.util.ForwardingList
 
remove(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
remove(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
remove(Object) - Method in class org.infinispan.commons.util.WeakValueHashMap
 
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 - Class in org.infinispan.persistence.modifications
Represents a CacheWriter.delete(Object) (Object)} modification
Remove(Object) - Constructor for class org.infinispan.persistence.modifications.Remove
 
remove() - Method in class org.infinispan.query.clustered.DistributedIterator
 
remove() - Method in class org.infinispan.query.impl.AbstractIterator
This method is not supported and should not be used.
remove() - Method in class org.infinispan.query.impl.NullFilteringIterator
 
remove(S, K) - Method in interface org.infinispan.registry.ClusterRegistry
 
remove(S, K) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
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.ReadOnlyDataContainerBackedKeySet
 
REMOVE_HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of removal hits.
REMOVE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_IF_UNMODIFIED_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of removal misses.
REMOVE_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REMOVE_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
removeAll(Collection<?>) - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
removeAll(Collection<?>) - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
removeAll(Collection<?>) - Method in class org.infinispan.commons.util.ForwardingList
 
removeAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
removeAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
removeAndAdd(String, String) - Method in class org.infinispan.lucene.impl.FileListOperations
Optimized implementation to perform both a remove and an add
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
Deprecated.
Asynchronous version of BasicCache.remove(Object).
removeAsync(Object, Object) - Method in interface org.infinispan.api.BasicCache
Deprecated.
Asynchronous version of ConcurrentMap.remove(Object, Object).
removeAsync(Object) - Method in class org.infinispan.CacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.CacheImpl
 
removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
removeAsync(Object) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #remove(Object).
removeAsync(Object, Object) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #remove(Object, Object).
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, PersistenceManager) - Constructor for class org.infinispan.commands.RemoveCacheCommand
 
RemoveCommand - Class in org.infinispan.commands.write
 
RemoveCommand(Object, Object, CacheNotifier, Set<Flag>, Equivalence) - Constructor for class org.infinispan.commands.write.RemoveCommand
 
RemoveCommand() - Constructor for class org.infinispan.commands.write.RemoveCommand
 
removeEntry(Object) - Method in class org.infinispan.persistence.support.Bucket
 
removeExpiredEntries(TimeService) - Method in class org.infinispan.persistence.support.Bucket
 
removeExtraBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
removeFromIndexes(Object, Object, TransactionContext) - Method in class org.infinispan.query.backend.QueryInterceptor
 
RemoveIfUnmodifiedOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "removeIfUnmodified" operation as defined by Hot Rod protocol specification.
RemoveIfUnmodifiedOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], long) - Constructor for class org.infinispan.client.hotrod.impl.operations.RemoveIfUnmodifiedOperation
 
removeInterceptor(int) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
removeInterceptor(int) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor at a specified position, where the first interceptor in the chain is at position 0 and the last one at getInterceptorChain().size() - 1.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Removes the interceptor of specified type.
removeInterceptor(int) - Method in class org.infinispan.CacheImpl
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.CacheImpl
 
removeInterceptor(int) - Method in class org.infinispan.interceptors.InterceptorChain
Removes the interceptor at the given postion.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Removes all the occurences of supplied interceptor type from the chain.
removeKeyFromBucket(Object, Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
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.
removeListener(Object) - Method in interface org.infinispan.registry.ClusterRegistry
Detaches a listener instance.
removeListener(Object) - Method in class org.infinispan.registry.ClusterRegistryImpl
 
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
 
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 - Class in org.infinispan.client.hotrod.impl.operations
Implement "remove" operation as described in Hot Rod protocol specification.
RemoveOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.RemoveOperation
 
RemoveOperation.Externalizer - Class in org.infinispan.atomic
 
removeOwner(int, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
removeProperty(String) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
removeProperty(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
removeRecoveryInformation(Long) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Same as RecoveryManager.removeRecoveryInformation(javax.transaction.xa.Xid) but identifies the tx by its internal id.
removeRecoveryInformation(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Remove recovery information stored on this node (doesn't involve rpc).
removeRecoveryInformation(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformation(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformationFromCluster(Collection<Address>, Xid, boolean, GlobalTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information associated with these Xids.
removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Same as #removeRecoveryInformationFromCluster(java.util.Collection but the transaction is identified by its internal id, and not by its xid.
removeRecoveryInformationFromCluster(Collection<Address>, Xid, boolean, GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.TransactionTable
 
removeRemoteTransaction(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
 
removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
removeWithVersion(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeWithVersion(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
Removes the given entry only if its version matches the supplied version.
removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
removeWithVersionAsync(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
removingServer(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
removingServer(SocketAddress) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
removingServer$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
renameFile(String, String) - Method in interface org.infinispan.lucene.impl.DirectoryExtensions
 
renameFile(String, String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
renameTo(File) - Method in class org.infinispan.io.GridFile
 
render(InputStream) - Method in class org.infinispan.cli.shell.Man2Ansi
 
renderBoolean(boolean) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
renderColor(Color, String) - Method in interface org.infinispan.cli.shell.Shell
 
renderColor(Color, String) - Method in class org.infinispan.cli.shell.ShellImpl
 
renderEntityName(Class<?>) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
renderEnum(E) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
RepeatableReadEntry - Class in org.infinispan.container.entries
An extension of ReadCommittedEntry that provides Repeatable Read semantics
RepeatableReadEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.RepeatableReadEntry
 
replace(K, V, Metadata) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
replace(K, V, V, Metadata) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
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, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #replace(K, V), which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
replace(K, V, V, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #replace(K, V, V), which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
replace(K, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replace(K, V, V) - Method in class org.infinispan.CacheImpl
 
replace(K, V) - Method in class org.infinispan.CacheImpl
 
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, Metadata) - Method in class org.infinispan.CacheImpl
 
replace(K, V, V, Metadata) - 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 - Class in org.infinispan.cli.commands.server
 
Replace() - Constructor for class org.infinispan.cli.commands.server.Replace
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replace(K, V, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replace(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.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.commons.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.commons.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.commons.api.BasicCache
An overloaded form of ConcurrentMap.replace(Object, Object, Object), which takes in lifespan parameters.
replace(K, V, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
replace(K, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
replace(K, V, V) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
replace(K, V) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
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, Metadata) - Method in class org.infinispan.DecoratedCache
 
replace(K, V, Metadata) - 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(String, String, BackupReceiver) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
REPLACE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_IF_UNMODIFIED_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REPLACE_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
replaceAll(EquivalentConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
 
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
Deprecated.
Asynchronous version of ConcurrentMap.replace(Object, Object).
replaceAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
replaceAsync(K, V, V) - Method in interface org.infinispan.api.BasicCache
Deprecated.
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.api.BasicCache
Deprecated.
replaceAsync(K, V) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, V) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.CacheImpl
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, V) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.CacheSupport
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceAsync(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #replace(Object, Object).
replaceAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #replace(Object, Object, long, TimeUnit).
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #replace(Object, Object, long, TimeUnit, long, TimeUnit).
replaceAsync(K, V, V) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #replace(Object, Object, Object).
replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #replace(Object, Object, Object, long, TimeUnit).
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of #replace(Object, Object, Object, long, TimeUnit, long, TimeUnit).
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) - 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, Metadata, Set<Flag>, Equivalence) - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
ReplaceIfUnmodifiedOperation - Class in org.infinispan.client.hotrod.impl.operations
Implement "replaceIfUnmodified" as defined by Hot Rod protocol specification.
ReplaceIfUnmodifiedOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int, long) - Constructor for class org.infinispan.client.hotrod.impl.operations.ReplaceIfUnmodifiedOperation
 
replaceInterceptor(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
replaceKey(Object, Object) - Method in class org.infinispan.commands.control.LockControlCommand
 
replaceKeys(Map<Object, Object>) - Method in class org.infinispan.commands.control.LockControlCommand
 
ReplaceOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements "Replace" operation as defined by Hot Rod protocol specification.
ReplaceOperation(Codec, TransportFactory, byte[], byte[], AtomicInteger, Flag[], byte[], int, int) - Constructor for class org.infinispan.client.hotrod.impl.operations.ReplaceOperation
 
replacePrimaryOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
replacePrimaryOwnerWithBackup(int, Address) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory.Builder
 
replaceProperties(String) - Static method in class org.infinispan.commons.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.commons.util.StringPropertyReplacer
Go through the input string and replace any occurance of ${p} with the props.getProperty(p) value.
replaceValue(Object, InternalCacheEntry) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
replaceValue(Object, InternalCacheEntry) - Method in class org.infinispan.context.impl.ImmutableContext
 
replaceValue(Object, InternalCacheEntry) - 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, InternalCacheEntry) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
 
replaceVersionRead(Object, EntryVersion) - Method in class org.infinispan.transaction.AbstractCacheTransaction
 
replaceVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Sets the version read fr this key, replacing the old version if it exists, i.e each invocation updates the version of the key.
replaceWithVersion(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceWithVersion(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersion(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersion(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
Replaces the given value only if its version matches the supplied version.
replaceWithVersion(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
A overloaded form of RemoteCache.replaceWithVersion(Object, Object, long) which takes in lifespan parameters.
replaceWithVersion(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
A overloaded form of RemoteCache.replaceWithVersion(Object, Object, long) which takes in lifespan and maximum idle time parameters.
replaceWithVersionAsync(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
replaceWithVersionAsync(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersionAsync(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
replaceWithVersionAsync(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replaceWithVersionAsync(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.ClearOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.Operation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.PutOperation
 
replay(Map<K, V>) - Method in class org.infinispan.atomic.RemoveOperation
 
REPLICABLE_COMMAND - Static variable in interface org.infinispan.marshall.core.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.core.Ids
 
REPLICATED_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.core.Ids
 
ReplicatedConsistentHash - Class in org.infinispan.distribution.ch
Special implementation of ConsistentHash for replicated caches.
ReplicatedConsistentHash(Hash, List<Address>, int[]) - Constructor for class org.infinispan.distribution.ch.ReplicatedConsistentHash
 
ReplicatedConsistentHash.Externalizer - Class in org.infinispan.distribution.ch
 
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
 
ReplicationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
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.
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() - 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() - 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_BALANCING_STRATEGY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
REQUEST_IGNORED_RESPONSE - Static variable in interface org.infinispan.marshall.core.Ids
 
REQUEST_MAGIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
REQUEST_PARSING_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
RequestBalancingStrategy - Interface in org.infinispan.client.hotrod.impl.transport.tcp
Defines how request are distributed between the servers for replicated caches.
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.
requireDistOrReplCache(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
requireDistOrReplCache(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
requireDistOrReplCache(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
requireDistOrReplCache(String) - Method in class org.infinispan.query.logging.Log_$logger
 
requireDistOrReplCache(String) - Method in interface org.infinispan.util.logging.Log
 
requireDistOrReplCache(String) - Method in class org.infinispan.util.logging.Log_$logger
 
requireDistOrReplCache$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
requireDistOrReplCache$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
requireDistOrReplCache$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
requireDistOrReplCache$str() - Method in class org.infinispan.query.logging.Log_$logger
 
requireDistOrReplCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
requiredParameterWasPassedNull(String) - Method in interface org.infinispan.lucene.logging.Log
 
requiredParameterWasPassedNull(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
requiredParameterWasPassedNull$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
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.
rescalingChunksize(String, long, int) - Method in interface org.infinispan.lucene.logging.Log
 
rescalingChunksize(String, long, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
rescalingChunksize$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
reset() - Method in interface org.infinispan.cli.CommandBuffer
 
reset() - Method in class org.infinispan.cli.impl.CommandBufferImpl
 
reset() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Resets variables maintaining the sum to zero.
reset() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
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 interface org.infinispan.stats.Stats
Reset statistics
reset() - Method in class org.infinispan.stats.StatsImpl
 
reset() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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.CacheWriterInterceptor
 
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.
resolveModuleLifecycles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
 
ResourceDMBean - Class in org.infinispan.jmx
This class was entirely copied from JGroups 2.7 (same name there).
ResourceDMBean(Object, ManageableComponentMetadata) - Constructor for class org.infinispan.jmx.ResourceDMBean
 
Response - Interface in org.infinispan.remoting.responses
A response to be sent back to a remote caller
RESPONSE_MAGIC - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
ResponseFilter - Interface in org.infinispan.remoting.rpc
A mechanism of filtering RPC responses.
responseFilter() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
responseFilter(ResponseFilter) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Sets the ResponseFilter.
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.
responseMode() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
responseMode(ResponseMode) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Sets the ResponseMode for the remote invocation.
restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
 
result(List<ProcessedCommand>, String, boolean) - Method in interface org.infinispan.cli.Context
 
result(List<ProcessedCommand>, String, boolean) - Method in class org.infinispan.cli.impl.ContextImpl
 
result(List<ProcessedCommand>, String, boolean) - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
result(List<ProcessedCommand>, String, boolean) - Method in interface org.infinispan.cli.io.IOAdapter
 
result(List<ProcessedCommand>, String, boolean) - Method in class org.infinispan.cli.io.StreamIOAdapter
 
ResultIterator - Interface in org.infinispan.query
Iterates over query results

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.commons.util.Base64.OutputStream
Resumes encoding of the stream.
resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.AbstractListenerImpl
 
resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
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.commons.util.ForwardingList
 
retainAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
retainAll(Collection<?>) - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
retrievalEncounteredException(Throwable) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
RETRIEVALS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of get operations.
retrieveFromRemoteSource(Object, InvocationContext, boolean, FlagAffectedCommand, boolean) - Method in class org.infinispan.interceptors.ClusteringInterceptor
Retrieves a cache entry from a remote source.
retrieveFromRemoteSource(Object, InvocationContext, boolean, FlagAffectedCommand, boolean) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
retrieveKeyFromLazyQuery(Cache<?, ?>, UUID, int) - Static method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
retrievingTm(TransactionManager) - Method in class org.infinispan.lucene.logging.Log_$logger
 
retrievingTm(TransactionManager) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
retrievingTm(TransactionManager) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
retrievingTm(TransactionManager) - Method in class org.infinispan.query.logging.Log_$logger
 
retrievingTm(TransactionManager) - Method in interface org.infinispan.util.logging.Log
 
retrievingTm(TransactionManager) - Method in class org.infinispan.util.logging.Log_$logger
 
retrievingTm$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
retrievingTm$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
retrievingTm$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
retrievingTm$str() - Method in class org.infinispan.query.logging.Log_$logger
 
retrievingTm$str() - Method in class org.infinispan.util.logging.Log_$logger
 
RetryOnFailureOperation<T> - Class in org.infinispan.client.hotrod.impl.operations
Base class for all the operations that need retry logic: if the operation fails due to connection problems, try with another available connection.
RetryOnFailureOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
RetryPrepareException - Exception in org.infinispan.interceptors.totalorder
Indicates the state transfer is running and the prepare should be retried.
RetryPrepareException() - Constructor for exception org.infinispan.interceptors.totalorder.RetryPrepareException
 
retryWaitTimeIncreaseFactorDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated() - Method in interface org.infinispan.util.logging.Log
 
retryWaitTimeIncreaseFactorDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
retryWaitTimeIncreaseFactorDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
returnPossiblePrevValue(Transport) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
returnVersionedOperationResponse(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
reverseIterator() - Method in interface org.infinispan.commons.util.ReversibleOrderedSet
 
ReversibleOrderedSet<E> - Interface in org.infinispan.commons.util
A set that allows reverse iteration of the set elements, exposed via the ReversibleOrderedSet.reverseIterator() method.
rewind() - Method in interface org.infinispan.commons.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.commons.util.Util
 
RiverCloseListener - Interface in org.infinispan.commons.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 - Class in org.infinispan.cli.commands.server
 
Rollback() - Constructor for class org.infinispan.cli.commands.server.Rollback
 
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() - 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
 
rootDirectoryIsNotADirectory(String) - Method in interface org.infinispan.lucene.logging.Log
 
rootDirectoryIsNotADirectory(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
rootDirectoryIsNotADirectory$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
rootType - Variable in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
RoundRobinBalancingStrategy - Class in org.infinispan.client.hotrod.impl.transport.tcp
Round-robin implementation for RequestBalancingStrategy.
RoundRobinBalancingStrategy() - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
rpc - Variable in class org.infinispan.distexec.DefaultExecutorService
 
RpcException - Exception in org.infinispan.remoting
Thrown when an RPC problem occurred on the caller.
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
 
RpcOptions - Class in org.infinispan.remoting.rpc
Classes that wraps all the configuration parameters to configure a remote invocation.
RpcOptions(long, TimeUnit, ResponseFilter, ResponseMode, boolean, boolean, boolean) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
 
rpcOptionsBuilder - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
RpcOptionsBuilder - Class in org.infinispan.remoting.rpc
It builds RpcOptions instances with the options to be used in remote invocations.
RpcOptionsBuilder(long, TimeUnit, ResponseMode, boolean) - Constructor for class org.infinispan.remoting.rpc.RpcOptionsBuilder
 
RpcOptionsBuilder(RpcOptions) - Constructor for class org.infinispan.remoting.rpc.RpcOptionsBuilder
Constructor based on existing RpcOptions
run() - Method in interface org.infinispan.cli.shell.Shell
 
run() - Method in class org.infinispan.cli.shell.ShellImpl
 
run() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.
run() - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
runCommitTx() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
runL1UpdateIfPossible(InternalCacheEntry) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
Attempts to the L1 update and set the value.
runPrepare() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
runRollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
 
rvrl - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 

S

safeClose(Statement) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
 
safeClose(Connection) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
 
safeClose(ResultSet) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
 
safeEquals(Object, Object) - Static method in class org.infinispan.commons.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
 
save() - Method in interface org.infinispan.cli.Config
 
save() - Method in class org.infinispan.cli.shell.ConfigImpl
 
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
 
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.
scope - Variable in class org.infinispan.registry.ScopedKey
 
SCOPED_KEY - Static variable in interface org.infinispan.marshall.core.Ids
 
ScopeDetector - Class in org.infinispan.factories.scopes
Retrieves the declared scope of a component
ScopeDetector() - Constructor for class org.infinispan.factories.scopes.ScopeDetector
 
ScopedKey<S,K> - Class in org.infinispan.registry
Used to support scoping for the cluster registry's entries.
ScopedKey(S, K) - Constructor for class org.infinispan.registry.ScopedKey
 
ScopedKey.Externalizer - Class in org.infinispan.registry
 
Scopes - Enum in org.infinispan.factories.scopes
The different scopes that can be declared for a component in the cache system.
Search - Class in org.infinispan.client.hotrod
 
search(long, EquivalentConcurrentHashMapV8.BiFun<? super K, ? super V, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a non-null result from applying the given search function on each (key, value), or null if none.
Search - Class in org.infinispan.query
Helper class to get a SearchManager out of an indexing enabled cache.
Search() - Constructor for class org.infinispan.query.Search
 
SearchableCacheConfiguration - Class in org.infinispan.query.backend
Class that implements org.hibernate.search.cfg.SearchConfiguration so that within Infinispan-Query, there is no need for a Hibernate Core configuration object.
SearchableCacheConfiguration(Class<?>[], Properties, EmbeddedCacheManager, ComponentRegistry) - Constructor for class org.infinispan.query.backend.SearchableCacheConfiguration
 
searchEntries(long, EquivalentConcurrentHashMapV8.Fun<Map.Entry<K, V>, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a non-null result from applying the given search function on each entry, or null if none.
searchKeys(long, EquivalentConcurrentHashMapV8.Fun<? super K, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a non-null result from applying the given search function on each key, or null if none.
SearchManager - Interface in org.infinispan.query
The SearchManager is the entry point to create full text queries on top of a cache.
SearchManagerImpl - Class in org.infinispan.query.impl
Class that is used to build CacheQuery
SearchManagerImpl(AdvancedCache<?, ?>) - Constructor for class org.infinispan.query.impl.SearchManagerImpl
 
SearchManagerImplementor - Interface in org.infinispan.query.spi
 
searchValues(long, EquivalentConcurrentHashMapV8.Fun<? super V, ? extends U>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a non-null result from applying the given search function on each value, or null if none.
SearchWorkCreator<T> - Interface in org.infinispan.query.backend
Creates collections of Work instances that should be performed by Hibernate-Search.
secureReadln(String) - Method in class org.infinispan.cli.io.ConsoleIOAdapter
 
secureReadln(String) - Method in interface org.infinispan.cli.io.IOAdapter
 
secureReadln(String) - Method in class org.infinispan.cli.io.StreamIOAdapter
 
seek(long) - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
seek(long) - Method in class org.infinispan.lucene.impl.SingleChunkIndexInput
 
SegmentReadLocker - Interface in org.infinispan.lucene.readlocks
SegmentReadLocker implementations have to make sure that segments are not deleted while they are being used by an IndexReader.
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.query.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in interface org.infinispan.util.logging.Log
 
segmentsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.query.logging.Log_$logger
 
segmentsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
selectExecutionNode(List<Address>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
selectExecutionNode(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
Self<S extends Self<S>> - Interface in org.infinispan.commons.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.commons.configuration.Self
 
self() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
self() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.cli.configuration.CLInterfaceLoaderConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder.BinaryTableManipulationConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
self() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
SelfDeliverFilter - Class in org.infinispan.remoting.responses
Used in Total Order based protocol.
SelfDeliverFilter(Address) - Constructor for class org.infinispan.remoting.responses.SelfDeliverFilter
 
sendKeyOperation(byte[], Transport, byte, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyOperation
 
sendNotification(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.interceptors.ActivationInterceptor
 
sendNotification(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
sendPutOperation(Transport, short, byte) - Method in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
SEPARATOR - Static variable in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
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
 
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.
SerializeWith - Annotation Type in org.infinispan.commons.marshall
Indicate that this class should be serialized with an instance of the given Externalizer class.
SerializeWith - Annotation Type in org.infinispan.marshall
Deprecated.
SerializeWithExtFactory - Class in org.infinispan.commons.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.commons.marshall.jboss.SerializeWithExtFactory
 
SerializeWithExtFactory - Class in org.infinispan.marshall.core
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.core.SerializeWithExtFactory
 
SERVER_ERROR_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
SERVER_LIST - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ServerCommand - Interface in org.infinispan.cli.commands
 
ServerConfiguration - Class in org.infinispan.client.hotrod.configuration
ServerConfiguration.
ServerConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
ServerConfigurationBuilder.
servers() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
servers() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
ServerStatistics - Interface in org.infinispan.client.hotrod
Defines the possible list of statistics defined by the Hot Rod server.
ServerStatisticsImpl - Class in org.infinispan.client.hotrod.impl
 
ServerStatisticsImpl() - Constructor for class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
ServiceFinder - Class in org.infinispan.commons.util
ServiceFinder is a ServiceLoader replacement which understands multiple classpaths
ServiceFinder() - Constructor for class org.infinispan.commons.util.ServiceFinder
 
set(K, V) - Method in class org.infinispan.AbstractDelegatingCache
Don't remove.
set(K, V) - Method in class org.infinispan.CacheSupport
This is intentionally a non-public method meant as an integration point for bytecode manipulation.
set(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
set(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
This is intentionally a non-public method meant as an integration point for bytecode manipulation.
set(T) - Method in class org.infinispan.commons.util.ByRef
 
set(int, E) - Method in class org.infinispan.commons.util.ForwardingList
 
setActiveContainer(String) - Method in interface org.infinispan.cli.connection.Connection
 
setActiveContainer(String) - Method in class org.infinispan.cli.connection.jmx.JMXConnection
 
setActual(Future<T>) - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureAdaptor
 
setAddress(Address) - Method in class org.infinispan.query.clustered.QueryResponse
 
setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setAscending(boolean) - Method in class org.infinispan.query.remote.client.QueryRequest.SortCriteria
 
setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributePath(String) - Method in class org.infinispan.query.remote.client.QueryRequest.SortCriteria
 
setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
 
setBucketId(Integer) - Method in class org.infinispan.persistence.support.Bucket
 
setBucketId(String) - Method in class org.infinispan.persistence.support.Bucket
 
setCache(Cache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
setCache(AdvancedCache<?, ?>) - Method in class org.infinispan.query.clustered.QueryBox
 
setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.query.impl.CommandInitializer
 
setCacheManagerNotifier(CacheManagerNotifier) - Method in class org.infinispan.factories.ComponentRegistry
 
setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setCacheName(String) - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
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
 
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
 
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
 
setConfiguration(GlobalConfiguration) - Method in class org.infinispan.remoting.transport.AbstractTransport
 
setConfiguration(Configuration) - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
setConnection(Connection) - Method in interface org.infinispan.cli.Context
 
setConnection(Connection) - Method in class org.infinispan.cli.impl.ContextImpl
 
setConnectionFactoryClass(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConnectionUrl(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
setConsistentHashAtEnd(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setConsistentHashAtStart(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
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
 
setCreated(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setDatasourceJndiLocation(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
setDependencies(DataContainer, TimeService) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
setDependencies(LockManager, DataContainer, EntryFactory, ClusteringDependentLogic, Configuration) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
setDependencies(TransactionTable, RpcManager, TimeService) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
setDependencies(PassivationManager, DataContainer) - Method in class org.infinispan.interceptors.PassivationInterceptor
 
setDriverClass(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
setEmitCompositeIntermediateKeys(boolean) - Method in class org.infinispan.commands.read.MapCombineCommand
 
setEmitCompositeIntermediateKeys(boolean) - Method in class org.infinispan.commands.read.ReduceCommand
 
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.
setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.tasks.GlobalKeySetTask
 
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
 
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
 
setExecuting(Future<T>) - Method in class org.infinispan.client.hotrod.impl.async.NotifyingFutureImpl
 
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
 
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.
setFlag(boolean, ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setFlags(Flag[]) - Method in class org.infinispan.client.hotrod.impl.operations.OperationsFactory
 
setFlags(Set<Flag>) - Method in class org.infinispan.commands.AbstractLocalFlagAffectedCommand
 
setFlags(Flag...) - Method in class org.infinispan.commands.AbstractLocalFlagAffectedCommand
 
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.LocalFlagAffectedCommand
Use it to store the flags from the InvocationContext into the Command before remoting the Command.
setFlags(Flag...) - Method in interface org.infinispan.commands.LocalFlagAffectedCommand
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
 
setForkJoinTaskTag(short) - Method in class org.infinispan.commons.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
 
setGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.control.LockControlCommand
 
setHash(Hash) - Method in class org.infinispan.client.hotrod.impl.consistenthash.ConsistentHashV1
 
setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setIllegalClassnames(String[]) - Method in class org.infinispan.checkstyle.checks.regexp.IllegalImport
Set the list of illegal import statements.
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.
setIndexName(String) - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
setInfinispanMarshaller(StreamingMarshaller) - Method in class org.infinispan.commons.marshall.jboss.ExtendedRiverUnmarshaller
 
setInternalCacheEntryFactory(InternalEntryFactory) - Method in class org.infinispan.persistence.remote.RemoteStore
 
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
 
setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
setJpqlString(String) - Method in class org.infinispan.query.remote.client.QueryRequest
 
setKey(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setKey(K) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setKeyInvalidationListener(StateConsumerImpl.KeyInvalidationListener) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
setKeys(Object[]) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
setLastModified(long) - Method in class org.infinispan.io.GridFile
 
setLastModified(long) - Method in class org.infinispan.lucene.FileMetadata
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setLastUsed(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setLength(int) - Method in class org.infinispan.io.GridFile.Metadata
 
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.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
 
setLockIntention(Object) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
setLocksHeldAtOrigin(Set<Object>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
setLogLevel() - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
 
setLookedUpEntriesTopology(int) - Method in class org.infinispan.transaction.RemoteTransaction
 
setMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
setMarshaller(Marshaller) - Method in interface org.infinispan.compat.TypeConverter
Marshaller to be used by the type converter to marshall/unmarshall contents.
setMarshaller(StreamingMarshaller) - Method in class org.infinispan.persistence.keymappers.MarshalledValueOrPrimitiveMapper
 
setMarshaller(StreamingMarshaller) - Method in interface org.infinispan.persistence.keymappers.MarshallingTwoWayKey2StringMapper
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
setMaxResults(int) - Method in class org.infinispan.query.remote.client.QueryRequest
 
setMergeView(boolean) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setMessage(String) - Method in class org.infinispan.checkstyle.checks.regexp.IllegalImport
 
setMetadata(Metadata) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
setMetadata(Metadata) - Method in class org.infinispan.commands.control.LockControlCommand
 
setMetadata(Metadata) - Method in interface org.infinispan.commands.MetadataAwareCommand
Sets metadata for this command.
setMetadata(Metadata) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setMetadata(Metadata) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setMetadata(Metadata) - Method in class org.infinispan.commands.write.PutMapCommand
 
setMetadata(Metadata) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
setMetadata(Metadata) - Method in interface org.infinispan.container.entries.metadata.MetadataAware
Set the metadata in the cache entry.
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMetadata
 
setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
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.commons.util.concurrent.AggregatingNotifyingFutureImpl
 
setNetworkFuture(Future<V>) - Method in class org.infinispan.commons.util.concurrent.DeferredReturnFuture
 
setNetworkFuture(Future<E>) - Method in class org.infinispan.commons.util.concurrent.NoOpFuture
 
setNetworkFuture(Future<T>) - Method in class org.infinispan.commons.util.concurrent.NotifyingFutureImpl
 
setNetworkFuture(Future<T>) - Method in interface org.infinispan.commons.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.
setNodeAddress(Address) - Method in class org.infinispan.query.clustered.ClusteredTopDocs
 
setNumResults(int) - Method in class org.infinispan.query.remote.client.QueryResponse
 
setOldMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setOldValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setOldValue(V) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
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
 
setOutputAdapter(IOAdapter) - Method in interface org.infinispan.cli.Context
 
setOutputAdapter(IOAdapter) - Method in class org.infinispan.cli.impl.ContextImpl
 
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.query.clustered.ClusteredQueryCommand
 
setParameters(int, Object[]) - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
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
 
setPassword(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
setPendingCount(int) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
Sets the pending count to the given value.
setPre(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
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
 
setProjection(String...) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
setProjection(String...) - Method in interface org.infinispan.query.dsl.QueryBuilder
 
setProjectionSize(int) - Method in class org.infinispan.query.remote.client.QueryResponse
 
setProperty(String, String) - Method in interface org.infinispan.cli.Context
 
setProperty(String, String) - Method in class org.infinispan.cli.impl.ContextImpl
 
setProperty(String, String) - Method in class org.infinispan.client.hotrod.impl.TypedProperties
 
setProperty(String, String) - Static method in class org.infinispan.commons.util.SysPropertyActions
 
setProperty(String, String) - Method in class org.infinispan.commons.util.TypedProperties
 
setProperty(String, Object) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Defines a single value.
setPutIfAbsent(boolean) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setQuitting(boolean) - Method in interface org.infinispan.cli.Context
 
setQuitting(boolean) - Method in class org.infinispan.cli.impl.ContextImpl
 
setRawResult(T) - Method in class org.infinispan.commons.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.commons.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
 
setRemote(boolean) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
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
 
setResults(List<WrappedMessage>) - Method in class org.infinispan.query.remote.client.QueryResponse
 
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.
setSearchWorkCreator(SearchWorkCreator<Object>) - Method in class org.infinispan.query.backend.QueryInterceptor
 
setSeed(long) - Method in class org.infinispan.commons.util.concurrent.jdk7backported.ThreadLocalRandom
Throws UnsupportedOperationException.
setSerializedWorkList(byte[]) - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
setServers(Collection<SocketAddress>) - Method in interface org.infinispan.client.hotrod.impl.transport.tcp.RequestBalancingStrategy
 
setServers(Collection<SocketAddress>) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.RoundRobinBalancingStrategy
 
setSize(long) - Method in class org.infinispan.lucene.FileMetadata
 
setSkipRemoteGet(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setSkipRemoteGet(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
setSkipRemoteGet(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setSkipRemoteGet(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setSkipRemoteGet(boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
setSortCriteria(List<QueryRequest.SortCriteria>) - Method in class org.infinispan.query.remote.client.QueryRequest
 
setStackTrace(StackTraceElement[]) - Method in exception org.infinispan.commons.marshall.NotSerializableException
 
setStartOffset(long) - Method in class org.infinispan.query.remote.client.QueryRequest
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.base.JmxStatsCommandInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.InvalidationInterceptor
 
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.query.impl.InfinispanQueryStatisticsInfo
 
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.
setStatisticsEnabled(boolean) - Method in interface org.infinispan.stats.Stats
Enables or disables statistics at runtime.
setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.StatsImpl
 
setStatus(int) - Method in class org.infinispan.transaction.tm.DummyTransaction
 
setSubgroupsMerged(List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
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.commons.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.commons.util.BeanUtils
Retrieves a setter name based on a field name passed in
setterName(Class<?>) - Static method in class org.infinispan.commons.util.BeanUtils
Returns a setter for a given class
setThreadContextClassLoader(Class) - Static method in class org.infinispan.commons.util.SysPropertyActions
 
setThreadContextClassLoader(ClassLoader) - Static method in class org.infinispan.commons.util.SysPropertyActions
 
setThreadLocal(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
Associate the InvocationContext parameter with the calling thread.
setThreadLocal(InvocationContext) - Method in class org.infinispan.context.InvocationContextContainerImpl
 
setTimeoutExceptionFactory(TimeoutExceptionFactory) - Method in class org.infinispan.query.impl.SearchManagerImpl
 
setTimeoutExceptionFactory(TimeoutExceptionFactory) - Method in interface org.infinispan.query.spi.SearchManagerImplementor
Define the timeout exception factory to customize the exception thrown when the query timeout is exceeded.
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
 
setTransactionSuccessful(boolean) - Method in class org.infinispan.notifications.cachelistener.event.EventImpl
 
setTransactionSynchronizedBlock(TotalOrderLatch) - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
Sets the TotalOrderLatch to be associated to this transaction
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
 
setType(Event.Type) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setUnlock(boolean) - Method in class org.infinispan.commands.control.LockControlCommand
 
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, InvocationContextFactory, TransactionTable, Configuration, Map<Byte, ModuleCommandInitializer>, RecoveryManager, StateProvider, StateConsumer, LockManager, InternalEntryFactory, MapReduceManager, StateTransferManager, BackupSender, CancellationService, TimeService) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
setUserName(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
setUseXaXid(boolean) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
 
setValid(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setValid(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
 
setValid(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
setValid(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setValue(Object) - Method in class org.infinispan.commands.write.RemoveCommand
 
setValue(V) - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
setValue(Object, String, Object) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
setValue(V) - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
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.metadata.MetadataMortalCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
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
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ClearCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.PutMapCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.RemoveCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setValueMatcher(ValueMatcher) - Method in interface org.infinispan.commands.write.WriteCommand
 
setValues(Object, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.ClusteredRepeatableReadEntry
 
setVersion(EntryVersion) - Method in interface org.infinispan.container.entries.versioned.Versioned
Sets the version on this entry.
setVersionsSeen(EntryVersionsMap) - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
setViewId(int) - Method in class org.infinispan.notifications.cachemanagerlistener.event.EventImpl
 
setWritable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setWritable(boolean) - Method in class org.infinispan.io.GridFile
 
setWrite(boolean) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
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() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
shared - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
shared(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
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.AbstractStoreConfigurationChildBuilder
 
shared() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
 
shared(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
sharedModeOnlyAllowed() - Method in interface org.infinispan.persistence.remote.logging.Log
 
sharedModeOnlyAllowed() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
sharedModeOnlyAllowed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
Shell - Interface in org.infinispan.cli.shell
Shell.
ShellImpl - Class in org.infinispan.cli.shell
ShellImpl.
ShellImpl() - Constructor for class org.infinispan.cli.shell.ShellImpl
 
ShellMode - Enum in org.infinispan.cli.shell
 
SHORT - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
shouldClose() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
shouldCommitDuringPrepare(PrepareCommand, TxInvocationContext) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
total order condition: only commits when it is remote context and the prepare has the flag 1PC set
shouldConnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
shouldDisconnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
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
 
shouldLoadKey(Object) - Method in class org.infinispan.persistence.CollectionKeyFilter
 
shouldLoadKey(Object) - Method in class org.infinispan.persistence.CompositeFilter
 
shouldLoadKey(Object) - Method in class org.infinispan.persistence.PrimaryOwnerFilter
 
shouldLoadKey(K) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.KeyFilter
 
shouldLock(Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
shouldModifyIndexes(FlagAffectedCommand, InvocationContext) - Method in class org.infinispan.query.backend.LocalQueryInterceptor
 
shouldModifyIndexes(FlagAffectedCommand, InvocationContext) - Method in class org.infinispan.query.backend.QueryInterceptor
 
shouldRetry(int) - Method in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
shouldTotalOrderRollbackBeInvokedRemotely(TxInvocationContext) - Static method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
showInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
shutdown() - Method in class org.infinispan.commons.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.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.LazyInitializingBlockingTaskAwareExecutorService
 
shutdown() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
shutdown() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
shutdown() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
shutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
ShutdownConfiguration - Class in org.infinispan.configuration.global
 
ShutdownConfigurationBuilder - Class in org.infinispan.configuration.global
 
shutdownHandlingCommand(ReplicableCommand) - Method in class org.infinispan.lucene.logging.Log_$logger
 
shutdownHandlingCommand(ReplicableCommand) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
shutdownHandlingCommand(ReplicableCommand) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
shutdownHandlingCommand(ReplicableCommand) - Method in class org.infinispan.query.logging.Log_$logger
 
shutdownHandlingCommand(ReplicableCommand) - Method in interface org.infinispan.util.logging.Log
 
shutdownHandlingCommand(ReplicableCommand) - Method in class org.infinispan.util.logging.Log_$logger
 
shutdownHandlingCommand$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
shutdownHandlingCommand$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
shutdownHandlingCommand$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
shutdownHandlingCommand$str() - Method in class org.infinispan.query.logging.Log_$logger
 
shutdownHandlingCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ShutdownHookBehavior - Enum in org.infinispan.configuration.global
Behavior of the JVM shutdown hook registered by the cache
shutdownNow() - Method in class org.infinispan.commons.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.distexec.DefaultExecutorService
 
shutdownNow() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
shutdownNow() - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
shutdownNow() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
shutdownNow() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
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.
SIMPLE_CLUSTERED_VERSION - Static variable in interface org.infinispan.marshall.core.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
 
SimpleClusteredVersion.Externalizer - Class in org.infinispan.container.versioning
 
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
 
simpleConnection() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
simpleConnection() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
simpleConnection() - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationChildBuilder
Configures this JDBC Cache Store to use a single connection to the database
SimpleConnectionFactory - Class in org.infinispan.persistence.jdbc.connectionfactory
Connection factory implementation that will create database connection on a per invocation basis.
SimpleConnectionFactory() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
SimpleConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.configuration
SimpleConnectionFactoryConfiguration.
SimpleConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
SimpleConnectionFactoryBuilder.
SimpleConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
SimpleImmutableEntry<K,V> - Class in org.infinispan.commons.util
Where is Java 1.6?
SimpleImmutableEntry(Map.Entry<K, V>) - Constructor for class org.infinispan.commons.util.SimpleImmutableEntry
 
SimpleImmutableEntry(K, V) - Constructor for class org.infinispan.commons.util.SimpleImmutableEntry
 
SingleChunkIndexInput - Class in org.infinispan.lucene.impl
SingleChunkIndexInput can be used instead of InfinispanIndexInput to read a segment when it has a size small enough to fit in a single chunk.
SingleChunkIndexInput(IndexInputContext) - Constructor for class org.infinispan.lucene.impl.SingleChunkIndexInput
 
SingleFileStore - Class in org.infinispan.persistence.file
A filesystem-based implementation of a CacheLoader.
SingleFileStore() - Constructor for class org.infinispan.persistence.file.SingleFileStore
 
SingleFileStoreConfiguration - Class in org.infinispan.configuration.cache
Defines the configuration for the single file cache store.
SingleFileStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties, String, int) - Constructor for class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
SingleFileStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
Single file cache store configuration builder.
SingleFileStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
SingleKeyNonTxInvocationContext - Class in org.infinispan.context
 
SingleKeyNonTxInvocationContext(boolean, Equivalence) - 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() - 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.
singleton() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
singleton() - 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.
SINGLETON_LIST - Static variable in interface org.infinispan.marshall.core.Ids
 
SingletonCacheWriter - Class in org.infinispan.persistence.support
SingletonStore is a delegating cache store used for situations when only one instance should interact with the underlying store.
SingletonCacheWriter(CacheWriter, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.support.SingletonCacheWriter
 
SingletonCacheWriter.PushStateException - Exception in org.infinispan.persistence.support
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
SingletonCacheWriter.SingletonStoreListener - Class in org.infinispan.persistence.support
Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
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 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 interface org.infinispan.configuration.cache.StoreConfiguration
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
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
 
SingletonStoreListener() - Constructor for class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
 
Site - Class in org.infinispan.cli.commands.server
 
Site() - Constructor for class org.infinispan.cli.commands.server.Site
 
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() - 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 interface org.infinispan.Cache
Returns a count of all elements in this cache and cache loader.
size() - Method in class org.infinispan.CacheImpl
 
size() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
size() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
size() - Method in class org.infinispan.commands.read.KeySetCommand.ExpiredFilteredKeySet
 
size() - Method in class org.infinispan.commands.read.ValuesCommand.ExpiredFilteredValues
 
size() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
 
size() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
size() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
 
size() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Returns the number of elements in this set.
size() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
Overriden only to avoid unneeded synchronization
size() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
size() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
size() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
size() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
size() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
size() - Method in class org.infinispan.commons.util.ForwardingList
 
size() - Method in class org.infinispan.commons.util.ImmutableListCopy
 
size() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList
 
size() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
size() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet
 
size() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
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
Deprecated.
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.lucene.cacheloader.LuceneCacheLoader
 
size() - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
 
size() - Method in class org.infinispan.persistence.file.SingleFileStore
 
size() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
size() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
size() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
size() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
size() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
size() - Method in class org.infinispan.persistence.remote.RemoteStore
 
size() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Returns the number of elements in the store.
size() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.infinispan.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.AbstractPerEntryLockContainer
 
size() - Method in interface org.infinispan.util.concurrent.locks.containers.LockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.OwnableReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.containers.ReentrantStripedLockContainer
 
size() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
SizeCommand - Class in org.infinispan.commands.read
Command to calculate the size of the cache
SizeCommand(DataContainer, Set<Flag>) - Constructor for class org.infinispan.commands.read.SizeCommand
 
sizeUncommitted() - Method in class org.infinispan.atomic.FineGrainedAtomicHashMapProxy
 
skip(long) - Method in class org.infinispan.io.GridInputStream
 
skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
skipL1Lookup(LocalFlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
skipL1Lookup(LocalFlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
skipRemoteGet() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
skipRemoteGet() - Method in interface org.infinispan.container.entries.CacheEntry
 
skipRemoteGet() - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
skipRemoteGet() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
skipRemoteGet() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
skipReplicationQueue() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
skipReplicationQueue(boolean) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Sets if the remote invocation must skip the ReplicationQueue.
skipSharedStores(InvocationContext, Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
skipSharedStores(InvocationContext, Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
skipTransactionCompleteCheck(boolean) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
skipTransactionCompleteCheck() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
skipTransactionCompleteCheck(boolean) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
skipTransactionCompleteCheck() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
skipTransactionCompleteCheck(boolean) - Method in interface org.infinispan.context.impl.TxInvocationContext
 
skipTransactionCompleteCheck() - Method in interface org.infinispan.context.impl.TxInvocationContext
 
skipTransactionCompleteCheck(boolean) - Method in class org.infinispan.transaction.RemoteTransaction
 
skipTransactionCompleteCheck() - Method in class org.infinispan.transaction.RemoteTransaction
 
skipWriteSkewCheck() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
skipWriteSkewCheck() - Method in interface org.infinispan.commands.tx.totalorder.TotalOrderPrepareCommand
 
skipWriteSkewCheck() - Method in class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
slice(String, long, long) - Method in class org.infinispan.lucene.impl.InfinispanIndexInputV4
 
SO_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
socketTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
socketTimeout() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
socketTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
socketTimeout(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
This property defines the maximum socket read timeout in milliseconds before giving up waiting for bytes from the server.
socketTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
socketTimeout() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
socketTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
socketTimeout(long) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
This property defines the maximum socket read timeout in milliseconds before giving up waiting for bytes from the server.
sort(Sort) - Method in interface org.infinispan.query.CacheQuery
Allows lucene to sort the results.
sort(Sort) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
sort(Sort) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
sortCriteria - Variable in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
SortCriteria - Class in org.infinispan.query.dsl.impl
 
SortCriteria() - Constructor for class org.infinispan.query.remote.client.QueryRequest.SortCriteria
 
SortCriteriaMarshaller - Class in org.infinispan.query.remote.client
 
SortCriteriaMarshaller() - Constructor for class org.infinispan.query.remote.client.SortCriteriaMarshaller
 
SortOrder - Enum in org.infinispan.query.dsl
Enumeration of the available sort directions.
SourceMigrator - Interface in org.infinispan.upgrade
Performs migration operations on the source server or cluster of servers
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
 
spliteratorV8() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.KeySetView
 
sqlFailureClosingConnection(Connection, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureClosingConnection(Connection, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureClosingConnection$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureFetchingAllStoredEntries(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureFetchingAllStoredEntries(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureFetchingAllStoredEntries$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureInsertingBucket(Bucket, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureInsertingBucket(Bucket, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureInsertingBucket$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureIntegratingState(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureIntegratingState(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureIntegratingState$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureLoadingKey(String, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureLoadingKey(String, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureLoadingKey$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureReadingKey(Object, String, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureReadingKey(Object, String, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureReadingKey$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureRemovingKeys(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureRemovingKeys(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureRemovingKeys$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureRetrievingConnection(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureRetrievingConnection(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureRetrievingConnection$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureStoringKey(String, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureStoringKey(String, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureStoringKey$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureStoringKeys(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureStoringKeys(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureStoringKeys$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureUnexpected(SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureUnexpected(SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureUnexpected$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureUpdatingBucket(Bucket, SQLException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
sqlFailureUpdatingBucket(Bucket, SQLException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sqlFailureUpdatingBucket$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
ssl() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
ssl() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
ssl() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
ssl() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
SSL Configuration
SslConfiguration - Class in org.infinispan.client.hotrod.configuration
SslConfiguration.
SslConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
SSLConfigurationBuilder.
SslConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
sslContext() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
sslContext(SSLContext) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
SslContextFactory - Class in org.infinispan.commons.util
SslContextFactory.
SslContextFactory() - Constructor for class org.infinispan.commons.util.SslContextFactory
 
sslInitializationException(Throwable) - Method in interface org.infinispan.commons.logging.Log
 
sslInitializationException(Throwable) - Method in class org.infinispan.commons.logging.Log_$logger
 
sslInitializationException(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
sslInitializationException(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sslInitializationException(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
sslInitializationException(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
sslInitializationException(Throwable) - Method in interface org.infinispan.util.logging.Log
 
sslInitializationException(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
sslInitializationException$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
sslInitializationException$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
sslInitializationException$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
sslInitializationException$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
sslInitializationException$str() - Method in class org.infinispan.query.logging.Log_$logger
 
sslInitializationException$str() - Method in class org.infinispan.util.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in class org.infinispan.lucene.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in class org.infinispan.query.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in interface org.infinispan.util.logging.Log
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in class org.infinispan.util.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup$str() - Method in class org.infinispan.query.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup$str() - Method in class org.infinispan.util.logging.Log_$logger
 
start() - Method in class org.infinispan.AbstractDelegatingCache
 
start() - Method in class org.infinispan.affinity.KeyAffinityServiceImpl
 
start() - Method in class org.infinispan.CacheImpl
 
Start - Class in org.infinispan.cli.commands.server
 
Start() - Constructor for class org.infinispan.cli.commands.server.Start
 
start() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
start(Codec, Configuration, AtomicInteger) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
start(Codec, Configuration, AtomicInteger) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
start() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
start() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
start() - Method in interface org.infinispan.commons.api.Lifecycle
 
start() - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
start() - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
 
start() - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
start() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
start() - Method in class org.infinispan.context.AbstractInvocationContextFactory
 
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.CacheMgmtInterceptor
 
start() - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
start() - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
Only does a sanity check.
start() - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
start() - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
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.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.lucene.cacheloader.LuceneCacheLoader
 
start() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
start() - Method in class org.infinispan.manager.DefaultCacheManager
 
start() - Method in class org.infinispan.marshall.core.CacheMarshaller
 
start() - Method in class org.infinispan.marshall.core.ExternalizerTable
 
start() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
start() - Method in class org.infinispan.marshall.core.JBossMarshaller
 
start() - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
start() - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
start() - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
 
start() - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
start() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
start() - Method in class org.infinispan.persistence.async.AsyncCacheLoader
 
start() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
start() - Method in class org.infinispan.persistence.cli.CLInterfaceLoader
 
start() - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
start() - Method in class org.infinispan.persistence.file.SingleFileStore
 
start() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
start(ConnectionFactoryConfiguration, ClassLoader) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
Starts the connection factory.
start(ConnectionFactoryConfiguration, ClassLoader) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ManagedConnectionFactory
 
start(ConnectionFactoryConfiguration, ClassLoader) - Method in class org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory
 
start(ConnectionFactoryConfiguration, ClassLoader) - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
start() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
start() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
start(ConnectionFactory) - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
start() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
start() - Method in class org.infinispan.persistence.remote.RemoteStore
 
start() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
start() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
start() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
 
start(Properties, BuildContext) - Method in class org.infinispan.query.backend.ComponentRegistryServiceProvider
 
start() - Method in class org.infinispan.query.backend.QueryInterceptor
 
start() - Method in class org.infinispan.query.impl.massindex.MapReduceMassIndexer
 
start() - Method in interface org.infinispan.query.MassIndexer
 
start() - Method in class org.infinispan.remoting.ReplicationQueueImpl
Starts the asynchronous flush queue.
start() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
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 class org.infinispan.CacheImpl
 
startBatch() - Method in interface org.infinispan.commons.api.BatchingCache
Starts a batch.
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.
startDelegate() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
startedReadingMap - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
startingJGroupsChannel() - Method in class org.infinispan.lucene.logging.Log_$logger
 
startingJGroupsChannel() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
startingJGroupsChannel() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
startingJGroupsChannel() - Method in class org.infinispan.query.logging.Log_$logger
 
startingJGroupsChannel() - Method in interface org.infinispan.util.logging.Log
 
startingJGroupsChannel() - Method in class org.infinispan.util.logging.Log_$logger
 
startingJGroupsChannel$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
startingJGroupsChannel$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
startingJGroupsChannel$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
startingJGroupsChannel$str() - Method in class org.infinispan.query.logging.Log_$logger
 
startingJGroupsChannel$str() - Method in class org.infinispan.util.logging.Log_$logger
 
startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startJGroupsChannelIfNeeded() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
startObjectInput(InputStream, boolean) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
startObjectInput(InputStream, boolean) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
startObjectInput(InputStream, boolean) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Create and open a new ObjectInput for the given input stream.
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
startObjectInput(InputStream, boolean) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Create and open a new ObjectInput for the given input stream.
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
startObjectOutput(OutputStream, boolean, int) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Create and open an ObjectOutput instance for the given output stream.
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
startObjectOutput(OutputStream, boolean, int) - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Create and open an ObjectOutput instance for the given output stream.
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
startOffset - Variable in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
startOffset(long) - Method in class org.infinispan.query.dsl.impl.BaseQueryBuilder
 
startOffset(long) - Method in interface org.infinispan.query.dsl.QueryBuilder
 
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
 
startRebalance(CacheTopology) - Method in class org.infinispan.topology.ClusterCacheStatus
 
state - Variable in class org.infinispan.factories.AbstractComponentRegistry
 
state - Variable in class org.infinispan.persistence.async.AsyncCacheLoader
 
state - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
 
State - Class in org.infinispan.persistence.async
 
STATE_CHUNK - Static variable in interface org.infinispan.marshall.core.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
 
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
 
StateConsumerImpl.KeyInvalidationListener - Interface in org.infinispan.statetransfer
 
stateLock - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
 
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
 
stateRetrievalConfigurationDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated() - Method in interface org.infinispan.util.logging.Log
 
stateRetrievalConfigurationDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
stateRetrievalConfigurationDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
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 - Class in org.infinispan.cli.commands.server
 
Stats() - Constructor for class org.infinispan.cli.commands.server.Stats
 
stats() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
stats() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
Stats - Interface in org.infinispan.stats
Stats.
STATS_REQUEST - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
STATS_RESPONSE - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
StatsImpl - Class in org.infinispan.stats
StatsImpl.
StatsImpl(InterceptorChain) - Constructor for class org.infinispan.stats.StatsImpl
 
StatsOperation - Class in org.infinispan.client.hotrod.impl.operations
Implements to the stats operation as defined by Hot Rod protocol specification.
StatsOperation(Codec, TransportFactory, byte[], AtomicInteger, Flag[]) - Constructor for class org.infinispan.client.hotrod.impl.operations.StatsOperation
 
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.client.hotrod.impl.RemoteCacheImpl
 
stop() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
stop() - Method in interface org.infinispan.commons.api.Lifecycle
 
stop() - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
stop() - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
stop() - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Stop the marshaller.
stop() - Method in class org.infinispan.context.InvocationContextContainerImpl
 
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 stopped.
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.lucene.cacheloader.LuceneCacheLoader
 
stop() - Method in class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
 
stop() - Method in class org.infinispan.manager.DefaultCacheManager
 
stop() - Method in class org.infinispan.marshall.core.CacheMarshaller
 
stop() - Method in class org.infinispan.marshall.core.ExternalizerTable
 
stop() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
stop() - Method in class org.infinispan.marshall.core.JBossMarshaller
 
stop() - Method in class org.infinispan.marshall.core.VersionAwareMarshaller
 
stop() - Method in class org.infinispan.marshall.LegacyStreamingMarshallerAdapter
Deprecated.
 
stop() - Method in interface org.infinispan.marshall.StreamingMarshaller
Deprecated.
Stop the marshaller.
stop() - Method in class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
stop() - Method in class org.infinispan.persistence.async.AsyncCacheLoader
 
stop() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
stop() - Method in class org.infinispan.persistence.cli.CLInterfaceLoader
 
stop() - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
stop() - Method in class org.infinispan.persistence.file.SingleFileStore
 
stop() - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
stop() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
Closes the connection factory, including all allocated connections etc.
stop() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ManagedConnectionFactory
 
stop() - Method in class org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory
 
stop() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
stop() - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
stop() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
stop() - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
stop() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
stop() - Method in class org.infinispan.persistence.remote.RemoteStore
 
stop() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.TaskContext
Invoked from within the CacheLoaderTask, in order to signal the AdvancedCacheLoader implementation that iteration should be stopped early (before iteration is finished).
stop() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
stop() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
stop() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
 
stop() - Method in class org.infinispan.persistence.TaskContextImpl
 
stop() - Method in class org.infinispan.query.backend.ComponentRegistryServiceProvider
 
stop() - Method in class org.infinispan.query.backend.QueryInterceptor
 
stop() - Method in class org.infinispan.remoting.ReplicationQueueImpl
Stops the asynchronous flush queue.
stop() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
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 class org.infinispan.lucene.logging.Log_$logger
 
stopBeforeDestroyFailed(CacheException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
stopBeforeDestroyFailed(CacheException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
stopBeforeDestroyFailed(CacheException) - Method in class org.infinispan.query.logging.Log_$logger
 
stopBeforeDestroyFailed(CacheException) - Method in interface org.infinispan.util.logging.Log
 
stopBeforeDestroyFailed(CacheException) - Method in class org.infinispan.util.logging.Log_$logger
 
stopBeforeDestroyFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
stopBeforeDestroyFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
stopBeforeDestroyFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
stopBeforeDestroyFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
stopBeforeDestroyFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
stopDelegate() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
stoppingRpcDispatcher() - Method in class org.infinispan.lucene.logging.Log_$logger
 
stoppingRpcDispatcher() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
stoppingRpcDispatcher() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
stoppingRpcDispatcher() - Method in class org.infinispan.query.logging.Log_$logger
 
stoppingRpcDispatcher() - Method in interface org.infinispan.util.logging.Log
 
stoppingRpcDispatcher() - Method in class org.infinispan.util.logging.Log_$logger
 
stoppingRpcDispatcher$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
stoppingRpcDispatcher$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
stoppingRpcDispatcher$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
stoppingRpcDispatcher$str() - Method in class org.infinispan.query.logging.Log_$logger
 
stoppingRpcDispatcher$str() - Method in class org.infinispan.util.logging.Log_$logger
 
store(TxInvocationContext) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
Store - Class in org.infinispan.persistence.modifications
Store(Object, MarshalledEntry) - Constructor for class org.infinispan.persistence.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.
StoreConfiguration - Interface in org.infinispan.configuration.cache
StoreConfiguration contains generic configuration elements available to all the stores.
StoreConfigurationBuilder<T extends StoreConfiguration,S extends StoreConfigurationBuilder<T,S>> - Interface in org.infinispan.configuration.cache
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
StoreConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
 
storeCurrentBuffer(boolean) - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
storeInBucket(MarshalledEntry, Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
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.
STORES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of put operations.
stores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
stores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
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() - 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).
StreamingMarshaller - Interface in org.infinispan.commons.marshall
A specialization of Marshaller that supports streams.
StreamingMarshaller - Interface in org.infinispan.marshall
Deprecated.
StreamingMarshallerAdapter - Class in org.infinispan.marshall
Deprecated.
StreamingMarshallerAdapter(StreamingMarshaller) - Constructor for class org.infinispan.marshall.StreamingMarshallerAdapter
Deprecated.
 
StreamIOAdapter - Class in org.infinispan.cli.io
 
StreamIOAdapter() - Constructor for class org.infinispan.cli.io.StreamIOAdapter
 
Streams - Class in org.infinispan.util.stream
A collection of stream related utility methods.
Streams() - Constructor for class org.infinispan.util.stream.Streams
 
strictPeerToPeer() - Method in class org.infinispan.configuration.global.TransportConfiguration
Deprecated.
Since 6.0, strictPeerToPeer is ignored and asymmetric clusters are always allowed.
strictPeerToPeer(Boolean) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Deprecated.
Since 6.0, strictPeerToPeer is ignored and asymmetric clusters are always allowed.
strictPeerToPeerDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
strictPeerToPeerDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
strictPeerToPeerDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
strictPeerToPeerDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
strictPeerToPeerDeprecated() - Method in interface org.infinispan.util.logging.Log
 
strictPeerToPeerDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
strictPeerToPeerDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
strictPeerToPeerDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
strictPeerToPeerDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
strictPeerToPeerDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
strictPeerToPeerDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
STRING - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
 
StringPropertyReplacer - Class in org.infinispan.commons.util
A utility class for replacing properties in strings.
StringPropertyReplacer() - Constructor for class org.infinispan.commons.util.StringPropertyReplacer
 
stringTable() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
stringTable() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder.MixedTableManipulationConfigurationBuilder
 
stringTable() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
Allows configuration of table-specific parameters such as column names and types for the table used to store entries with string keys
stringTable() - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationChildBuilder
Allows configuration of table-specific parameters such as column names and types for the table used to store entries with string keys
stringToElement(String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
stringToKey(String, ClassLoader) - Method in class org.infinispan.query.backend.KeyTransformationHandler
 
StripedLock - Class in org.infinispan.util.concurrent.locks
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
StripedLock() - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
This constructor just calls StripedLock.StripedLock(int) with a default concurrency value of 20.
StripedLock(int) - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
subList(int, int) - Method in class org.infinispan.commons.util.ForwardingList
 
subList(int, int) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
submit(ForkJoinTask<T>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
Submits a ForkJoinTask for execution.
submit(Callable<T>) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
 
submit(Runnable, T) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
 
submit(Runnable) - Method in class org.infinispan.commons.util.concurrent.jdk8backported.ForkJoinPool
 
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<Void>) - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
submit(Runnable, Void) - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submitEverywhere(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
 
submitEverywhere(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.core.Ids
 
SuccessfulResponse - Class in org.infinispan.remoting.responses
A successful response
SuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
suggestCustomInterceptorInheritance(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
suggestCustomInterceptorInheritance(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
suggestCustomInterceptorInheritance(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
suggestCustomInterceptorInheritance(String) - Method in class org.infinispan.query.logging.Log_$logger
 
suggestCustomInterceptorInheritance(String) - Method in interface org.infinispan.util.logging.Log
 
suggestCustomInterceptorInheritance(String) - Method in class org.infinispan.util.logging.Log_$logger
 
suggestCustomInterceptorInheritance$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
suggestCustomInterceptorInheritance$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
suggestCustomInterceptorInheritance$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
suggestCustomInterceptorInheritance$str() - Method in class org.infinispan.query.logging.Log_$logger
 
suggestCustomInterceptorInheritance$str() - Method in class org.infinispan.util.logging.Log_$logger
 
sum() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Returns the current sum.
sumThenReset() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
supportsConcurrentUpdates() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Deprecated.
this option is always true and cannot be modified since version 5.3
supportsConcurrentUpdates(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Deprecated. 
supportsInvocation(Flag) - Method in interface org.infinispan.compat.TypeConverter
Indicates whether this type converter supports a particular type of operation.
supportsKey(Class<?>) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
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.commons.util.Base64.OutputStream
Suspends encoding of the stream.
suspendIfNeeded() - Method in class org.infinispan.notifications.AbstractListenerImpl
 
suspendIfNeeded() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
suspendIfNeeded() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
swapPrimaryOwnersWithBackups(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
 
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.core.Ids
 
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.
syncCommitPhase() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
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
 
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(Cache<Object, Object>) - Method in class org.infinispan.persistence.cli.upgrade.CLInterfaceTargetMigrator
 
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, Equivalence<Object>) - 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() - 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.commons.util
Privileged actions for the package
SysPropertyActions() - Constructor for class org.infinispan.commons.util.SysPropertyActions
 
SystemUtils - Class in org.infinispan.cli.util
SystemUtils.
SystemUtils() - Constructor for class org.infinispan.cli.util.SystemUtils
 

T

table() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfiguration
 
table - Variable in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
table() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
Allows configuration of table-specific parameters such as column names and types
table() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
table() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
Allows configuration of table-specific parameters such as column names and types
tableExists(Connection, TableName) - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
tableExists(Connection) - Method in class org.infinispan.persistence.jdbc.TableManipulation
 
TableManipulation - Class in org.infinispan.persistence.jdbc
Contains all the logic of manipulating the table, including creating it if needed and access operations like inserting, selecting etc.
TableManipulation(TableManipulationConfiguration) - Constructor for class org.infinispan.persistence.jdbc.TableManipulation
 
TableManipulation() - Constructor for class org.infinispan.persistence.jdbc.TableManipulation
 
tableManipulationAttributeNotSet(String) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
tableManipulationAttributeNotSet(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
tableManipulationAttributeNotSet$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
TableManipulationConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
TableManipulationConfigurationBuilder<B extends AbstractJdbcStoreConfigurationBuilder<?,B>,S extends TableManipulationConfigurationBuilder<B,S>> - Class in org.infinispan.persistence.jdbc.configuration
TableManipulationConfigurationBuilder.
TableName - Class in org.infinispan.persistence.jdbc
Value object for table name operations.
TableName(String, String, String) - Constructor for class org.infinispan.persistence.jdbc.TableName
 
tableNamePrefix() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
tableNamePrefix(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Sets the prefix for the name of the table where the data will be stored.
take() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
take() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
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
TaskContextImpl - Class in org.infinispan.persistence
 
TaskContextImpl() - Constructor for class org.infinispan.persistence.TaskContextImpl
 
taskId - Variable in class org.infinispan.distexec.mapreduce.MapReduceTask
 
TCP_NO_DELAY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
tcpNoDelay(boolean) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
tcpNoDelay() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
tcpNoDelay(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
tcpNoDelay(boolean) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Affects TCP NODELAY on the TCP stack.
tcpNoDelay(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
tcpNoDelay() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
tcpNoDelay(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
tcpNoDelay(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Affects TCP NODELAY on the TCP stack.
TcpTransport - Class in org.infinispan.client.hotrod.impl.transport.tcp
Transport implementation based on TCP.
TcpTransport(SocketAddress, TransportFactory) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
TcpTransportFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
TcpTransportFactory() - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
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.Control - Class in org.infinispan.factories
 
testListenerClassValidity(Class<?>) - Static method in class org.infinispan.notifications.AbstractListenerImpl
Tests if a class is properly annotated as a CacheListener and returns the Listener annotation.
testListenerMethodValidity(Method, Class<?>, String) - Static method in class org.infinispan.notifications.AbstractListenerImpl
 
testOnBorrow() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
testOnBorrow(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Indicates whether connections should be validated before being taken from the pool by sending an TCP packet to the server.
testOnReturn() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
testOnReturn(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Indicates whether connections should be validated when being returned to the pool sending an TCP packet to the server.
testWhileIdle() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
testWhileIdle(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Indicates whether or not idle connections should be validated by sending an TCP packet to the server, during idle connection eviction runs.
testWhileIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
testWhileIdle(boolean) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Indicates whether or not idle connections should be validated by sending an TCP packet to the server, during idle connection eviction runs.
thirdPartySuspected(Address, SuspectException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
thirdPartySuspected(Address, SuspectException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
thirdPartySuspected(Address, SuspectException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
thirdPartySuspected(Address, SuspectException) - Method in class org.infinispan.query.logging.Log_$logger
 
thirdPartySuspected(Address, SuspectException) - Method in interface org.infinispan.util.logging.Log
 
thirdPartySuspected(Address, SuspectException) - Method in class org.infinispan.util.logging.Log_$logger
 
thirdPartySuspected$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
thirdPartySuspected$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
thirdPartySuspected$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
thirdPartySuspected$str() - Method in class org.infinispan.query.logging.Log_$logger
 
thirdPartySuspected$str() - Method in class org.infinispan.util.logging.Log_$logger
 
THREAD_NAME - Static variable in class org.infinispan.client.hotrod.impl.async.DefaultAsyncExecutorFactory
 
threadDump() - Static method in class org.infinispan.commons.util.Util
 
ThreadLocalRandom - Class in org.infinispan.commons.util.concurrent.jdk7backported
A random number generator isolated to the current thread.
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.
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
 
time() - Method in class org.infinispan.util.DefaultTimeService
 
time() - Method in interface org.infinispan.util.TimeService
 
TIME_SINCE_START - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of seconds since Hot Rod started.
timeBetweenEvictionRuns() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
timeBetweenEvictionRuns(long) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Indicates how long the eviction thread should sleep before "runs" of examining idle connections.
timeBetweenEvictionRuns() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
timeBetweenEvictionRuns(long) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Indicates how long the eviction thread should sleep before "runs" of examining idle connections.
timedOutWaitingForExpiredEntriesToBePurged(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged(Throwable) - Method in interface org.infinispan.util.logging.Log
 
timedOutWaitingForExpiredEntriesToBePurged(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged$str() - Method in class org.infinispan.query.logging.Log_$logger
 
timedOutWaitingForExpiredEntriesToBePurged$str() - Method in class org.infinispan.util.logging.Log_$logger
 
timeDuration(long, TimeUnit) - Method in class org.infinispan.util.DefaultTimeService
 
timeDuration(long, long, TimeUnit) - Method in class org.infinispan.util.DefaultTimeService
 
timeDuration(long, TimeUnit) - Method in interface org.infinispan.util.TimeService
It is equivalent to timeDuration(startTime, time(), outputTimeUnit).
timeDuration(long, long, TimeUnit) - Method in interface org.infinispan.util.TimeService
 
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
timeout(long, TimeUnit) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
timeout(TimeUnit) - Method in class org.infinispan.distexec.mapreduce.MapReduceTask
 
timeout(long, TimeUnit) - Method in interface org.infinispan.query.CacheQuery
Set the timeout for this query.
timeout(long, TimeUnit) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
timeout(long, TimeUnit) - Method in class org.infinispan.query.impl.CacheQueryImpl
 
timeout() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
timeout(long, TimeUnit) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Sets the timeout value and its TimeUnit.
timeout(TimeUnit) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
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
 
timeoutWaitingUntilTransactionPrepared(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared(String) - Method in class org.infinispan.query.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared(String) - Method in interface org.infinispan.util.logging.Log
 
timeoutWaitingUntilTransactionPrepared(String) - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared$str() - Method in class org.infinispan.query.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared$str() - Method in class org.infinispan.util.logging.Log_$logger
 
TimeService - Interface in org.infinispan.util
Encapsulates all the time related logic in this interface.
timestampColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
timestampColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The name of the database column used to store the timestamps
timestampColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
timestampColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The type of the database column used to store the timestamps
timestampOfFirstEntryToExpire() - Method in class org.infinispan.persistence.support.Bucket
 
timeUnit() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
tm_ - Variable in class org.infinispan.transaction.tm.DummyTransaction
 
toArray() - Method in class org.infinispan.commons.util.ForwardingList
 
toArray(T[]) - Method in class org.infinispan.commons.util.ForwardingList
 
toArray() - Method in class org.infinispan.commons.util.ImmutableListCopy
 
toArray(T[]) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
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.ReadOnlyDataContainerBackedKeySet
 
toArray(T[]) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
 
toAsync() - Method in enum org.infinispan.configuration.cache.CacheMode
 
toBuilder() - Method in interface org.infinispan.query.dsl.FilterConditionContext
Get the QueryBuilder that created this context.
toClassArray(String[], ClassLoader) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
toEntrySet(AdvancedCacheLoader, AdvancedCacheLoader.KeyFilter, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
 
toHexString(byte[]) - Static method in class org.infinispan.commons.util.Util
 
toHexString(byte[], int) - Static method in class org.infinispan.commons.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.metadata.MetadataImmortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
toInternalCacheValue() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Creates a representation of this entry as an InternalCacheValue.
toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
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
 
toJdkAccessOrder() - Method in enum org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
 
toJDKByteBuffer() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
toJGroupsAddress(Address) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
toKeySet(AdvancedCacheLoader, AdvancedCacheLoader.KeyFilter) - Static method in class org.infinispan.persistence.PersistenceUtil
 
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.core.Ids
 
TOPOLOGY_AWARE_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.core.Ids
 
TOPOLOGY_AWARE_SYNC_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.marshall.core.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
 
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
 
TopologyChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the ConsistentHash implementation in use by the DistributionManager changes due to a change in cluster topology.
TopologyChangedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
The event passed in to methods annotated with TopologyChanged.
topologyId - Variable in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
topologyId(AtomicInteger) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
topologyId - Variable in class org.infinispan.transaction.AbstractCacheTransaction
 
TopologyIdUpdater() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
 
TopologyInfo - Class in org.infinispan.distribution.topologyaware
This class holds the topology hierarchy of a cache's members.
TopologyInfo(Collection<Address>, Map<Address, Float>) - 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.
toStr(Object) - Static method in class org.infinispan.commons.util.Util
 
toStr(Collection<E>) - Static method in class org.infinispan.commons.util.Util
 
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.cli.connection.jmx.JMXConnection
 
toString() - Method in class org.infinispan.cli.connection.jmx.remoting.JMXRemotingUrl
 
toString() - Method in class org.infinispan.cli.connection.jmx.rmi.JMXRMIUrl
 
toString() - Method in class org.infinispan.cli.impl.CommandBufferImpl
 
toString() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
toString() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
toString() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
 
toString() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
toString() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
toString() - Method in exception org.infinispan.client.hotrod.exceptions.HotRodClientException
 
toString() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
toString() - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
toString() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
toString() - Method in class org.infinispan.commands.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.RemoveCacheCommand
 
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.VersionedCommitCommand
 
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(Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
 
toString(Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
 
toString(Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
Returns a string representation of the given object.
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.commons.io.ByteBufferImpl
 
toString() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
toString() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a string representation of this map.
toString() - Method in class org.infinispan.commons.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.commons.util.concurrent.jdk8backported.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class org.infinispan.commons.util.FastCopyHashMap
Returns a string representation of this map.
toString() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
toString() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
toString() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
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.ClusteringConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
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.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.LockingConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
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.SingleFileStoreConfiguration
 
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(Element) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
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.metadata.MetadataImmortalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
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.versioning.NumericVersion
 
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.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.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
 
toString() - Method in class org.infinispan.lucene.ChunkCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileListCacheKey
Changing the encoding could break backwards compatibility
toString() - Method in class org.infinispan.lucene.FileMetadata
 
toString() - Method in class org.infinispan.lucene.FileReadLockKey
 
toString() - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
 
toString() - Method in class org.infinispan.manager.DefaultCacheManager
 
toString() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
toString() - Method in class org.infinispan.marshall.core.MarshalledValue
 
toString() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
toString() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
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.persistence.cli.configuration.CLInterfaceLoaderConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
toString() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
toString() - Method in class org.infinispan.persistence.jdbc.connectionfactory.SimpleConnectionFactory
 
toString() - Method in class org.infinispan.persistence.jdbc.TableName
 
toString() - Method in class org.infinispan.persistence.modifications.ModificationsList
 
toString() - Method in class org.infinispan.persistence.modifications.Remove
 
toString() - Method in class org.infinispan.persistence.modifications.Store
 
toString() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
toString() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfiguration
 
toString() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
toString() - Method in class org.infinispan.persistence.support.Bucket
 
toString() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
 
toString() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
toString() - Method in class org.infinispan.query.dsl.impl.SortCriteria
 
toString(Object) - Method in class org.infinispan.query.impl.DefaultTransformer
 
toString(Object) - Method in interface org.infinispan.query.Transformer
 
toString() - Method in class org.infinispan.remoting.responses.InvalidResponse
 
toString() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
toString() - Method in class org.infinispan.remoting.responses.ValidResponse
 
toString() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
toString() - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
 
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.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.totalorder.TotalOrderLatchImpl
 
toString() - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
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.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 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.commons.util.ReflectionUtil
 
toSync() - Method in enum org.infinispan.configuration.cache.CacheMode
 
TOTAL_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Number of entries stored in Hot Rod server since the server started running.
TOTAL_ORDER_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
totalOrder - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
totalOrder() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
totalOrder(boolean) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
 
totalOrderAnycastPrepare(Collection<Address>, PrepareCommand, ResponseFilter) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
totalOrderBroadcastPrepare(PrepareCommand, ResponseFilter) - Method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
TotalOrderCommitCommand - Class in org.infinispan.commands.tx.totalorder
Commit Command used in the 2nd phase of 2PC.
TotalOrderCommitCommand(String, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderCommitCommand
 
TotalOrderCommitCommand(String) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderCommitCommand
 
TotalOrderDistributionInterceptor - Class in org.infinispan.interceptors.totalorder
This interceptor handles distribution of entries across a cluster, as well as transparent lookup, when the total order based protocol is enabled
TotalOrderDistributionInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
 
totalOrderExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
totalOrderExecutor() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
TotalOrderInterceptor - Class in org.infinispan.interceptors.totalorder
Created to control the total order validation.
TotalOrderInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
 
TotalOrderLatch - Interface in org.infinispan.transaction.totalorder
Behaves as a latch between org.infinispan.commands.tx.PrepareCommand delivered in total order to coordinate conflicting transactions and between org.infinispan.commands.tx.PrepareCommand and state transfer (blocking the prepare until the state transfer is finished and blocking the state transfer until all the prepared transactions has finished)
TotalOrderLatchImpl - Class in org.infinispan.transaction.totalorder
Implementation of TotalOrderLatch
TotalOrderLatchImpl(String) - Constructor for class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 
TotalOrderManager - Class in org.infinispan.transaction.totalorder
This class behaves as a synchronization point between incoming transactions (totally ordered) and between incoming transactions and state transfer.
TotalOrderManager() - Constructor for class org.infinispan.transaction.totalorder.TotalOrderManager
 
TotalOrderNonVersionedPrepareCommand - Class in org.infinispan.commands.tx.totalorder
Command corresponding to the 1st phase of 2PC when Total Order based protocol is used.
TotalOrderNonVersionedPrepareCommand(String, GlobalTransaction, WriteCommand...) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
TotalOrderNonVersionedPrepareCommand(String, GlobalTransaction, List<WriteCommand>) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
TotalOrderNonVersionedPrepareCommand(String) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
TotalOrderPrepareCommand - Interface in org.infinispan.commands.tx.totalorder
Interface with the utilities methods that the prepare command must have when Total Order based protocol is used
TotalOrderRemoteTransactionState - Class in org.infinispan.transaction
Represents a state for a Remote Transaction when the Total Order based protocol is used.
TotalOrderRemoteTransactionState(GlobalTransaction) - Constructor for class org.infinispan.transaction.TotalOrderRemoteTransactionState
 
TotalOrderRollbackCommand - Class in org.infinispan.commands.tx.totalorder
The 2nd phase command of 2PC, used when a transaction must be aborted.
TotalOrderRollbackCommand(String, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderRollbackCommand
 
TotalOrderRollbackCommand(String) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderRollbackCommand
 
TotalOrderStateTransferInterceptor - Class in org.infinispan.interceptors.totalorder
Synchronizes the incoming totally ordered transactions with the state transfer.
TotalOrderStateTransferInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
 
totalOrderTxCommit(TxInvocationContext) - Static method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
totalOrderTxRollback(TxInvocationContext) - Static method in class org.infinispan.interceptors.base.BaseRpcInterceptor
 
TotalOrderVersionedCommitCommand - Class in org.infinispan.commands.tx.totalorder
Command corresponding to the 2nd phase of 2PC.
TotalOrderVersionedCommitCommand(String, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedCommitCommand
 
TotalOrderVersionedCommitCommand(String) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedCommitCommand
 
TotalOrderVersionedDistributionInterceptor - Class in org.infinispan.interceptors.totalorder
This interceptor is used in total order in distributed mode when the write skew check is enabled.
TotalOrderVersionedDistributionInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
TotalOrderVersionedEntryWrappingInterceptor - Class in org.infinispan.interceptors.totalorder
Wrapping Interceptor for Total Order protocol when versions are needed
TotalOrderVersionedEntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
 
TotalOrderVersionedPrepareCommand - Class in org.infinispan.commands.tx.totalorder
Command corresponding to the 1st phase of 2PC when Total Order based protocol is used.
TotalOrderVersionedPrepareCommand(String, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
TotalOrderVersionedPrepareCommand(String) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
toTypedProperties(Properties) - Static method in class org.infinispan.client.hotrod.impl.TypedProperties
Factory method that converts a JDK Properties instance to an instance of TypedProperties, if needed.
toTypedProperties(Properties) - Static method in class org.infinispan.commons.util.TypedProperties
Factory method that converts a JDK Properties instance to an instance of TypedProperties, if needed.
toTypedProperties(Properties) - Static method in class org.infinispan.util.TypedProperties
Deprecated.
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
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.metadata.MetadataMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
touch() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
touch() - Method in class org.infinispan.lucene.FileMetadata
 
touchFile(String) - Method in class org.infinispan.lucene.InfinispanDirectory
Deprecated.
toURI() - Method in class org.infinispan.io.GridFile
 
toURL() - Method in class org.infinispan.io.GridFile
 
trace - Static variable in class org.infinispan.commons.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.core.Ids
 
TransactionalEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
An event subtype that includes a transaction context - if one exists - as well as a boolean as to whether the call originated locally or remotely.
TransactionalEventTransactionContext - Class in org.infinispan.query.backend
This class implements the TransactionContext interface.
TransactionalEventTransactionContext(TransactionManager, TransactionSynchronizationRegistry) - Constructor for class org.infinispan.query.backend.TransactionalEventTransactionContext
Creates a new instance of NodeModifiedTransactionContext.
TransactionalInvocationContextFactory - Class in org.infinispan.context
Invocation context to be used for transactional caches.
TransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.TransactionalInvocationContextFactory
 
TransactionalLockFactory - Class in org.infinispan.lucene.locking
Factory for locks obtained in InfinispanDirectory, this factory produces instances of TransactionalSharedLuceneLock.
TransactionalLockFactory(Cache<?, ?>, String) - Constructor for class org.infinispan.lucene.locking.TransactionalLockFactory
 
TransactionBoundaryCommand - Interface in org.infinispan.commands.tx
An transaction boundary command that allows the retrieval of an attached GlobalTransaction
TransactionCompleted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and the transaction completes, either with a commit or a rollback.
TransactionCompletedEvent<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
 
transactionDataReceived(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
transactionDataReceived(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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
 
transactionManager - Variable in class org.infinispan.atomic.AtomicHashMapProxy
 
transactionManager - Variable in class org.infinispan.CacheImpl
 
transactionManager - Variable in class org.infinispan.query.backend.QueryInterceptor
 
TransactionManagerFactory - Class in org.infinispan.factories
Uses a number of mechanisms to retrieve a transaction manager.
TransactionManagerFactory() - Constructor for class org.infinispan.factories.TransactionManagerFactory
 
transactionManagerLookup() - 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.
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.
transactionProtocol() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
transactionProtocol(TransactionProtocol) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
TransactionProtocol - Enum in org.infinispan.transaction
Enumerate with the possible commits protocols.
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 class org.infinispan.lucene.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.query.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology(Address, int, int) - Method in interface org.infinispan.util.logging.Log
 
transactionsRequestedByNodeWithOlderTopology(Address, int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.query.logging.Log_$logger
 
transactionsRequestedByNodeWithOlderTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionSynchronizationRegistry - Variable in class org.infinispan.query.backend.QueryInterceptor
 
TransactionSynchronizationRegistryFactory - Class in org.infinispan.factories
Factory for the TransactionSynchronizationRegistry
TransactionSynchronizationRegistryFactory() - Constructor for class org.infinispan.factories.TransactionSynchronizationRegistryFactory
 
transactionSynchronizationRegistryLookup() - 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.commons.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.commons.util.InfinispanCollections.MapMakerFunction
Transforms the given input into a key/value pair for use in a map
Transformable - Annotation Type in org.infinispan.query
If you annotate your object with this, it can be used as a valid key for Infinispan to index.
transformCollectionToMap(Collection<E>, InfinispanCollections.MapMakerFunction<K, V, E>) - Static method in class org.infinispan.commons.util.InfinispanCollections
Given a collection, transforms the collection to a map given a InfinispanCollections.MapMakerFunction
Transformer - Interface in org.infinispan.query
The task of this interface is to convert keys from their original types to a String representation (which can be used in Lucene) and vice versa.
transformMapValue(Map<K, E>, InfinispanCollections.Function<E, V>) - Static method in class org.infinispan.commons.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.core.Ids
 
TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.marshall.core.Ids
 
TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.marshall.core.Ids
 
TRANSIENT_VALUE - Static variable in interface org.infinispan.marshall.core.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, Object, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheEntry
 
TransientCacheEntry.Externalizer - Class in org.infinispan.container.entries
 
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
 
TransientMortalCacheEntry - Class in org.infinispan.container.entries
A cache entry that is both transient and mortal.
TransientMortalCacheEntry(Object, Object, long, long, long) - 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
 
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.Externalizer - Class in org.infinispan.container.entries
 
Transport - Interface in org.infinispan.client.hotrod.impl.transport
Transport abstraction.
transport() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
transport() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
transport() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
 
transport() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
transport(Transport) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Class that represents a network transport.
Transport - Interface in org.infinispan.remoting.transport
An interface that provides a communication link with remote caches.
TRANSPORT_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
TransportConfiguration - Class in org.infinispan.configuration.global
 
TransportConfigurationBuilder - Class in org.infinispan.configuration.global
Configures the transport used for network communications across the cluster.
TransportException - Exception in org.infinispan.client.hotrod.exceptions
Indicates a communication exception with the Hot Rod server: e.g.
TransportException(String, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(String, Throwable, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
TransportException(Throwable, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
 
transportFactory(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
transportFactory(Class<? extends TransportFactory>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
transportFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
transportFactory(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
transportFactory(Class<? extends TransportFactory>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
transportFactory(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Controls which transport to use.
transportFactory(Class<? extends TransportFactory>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Controls which transport to use.
transportFactory - Variable in class org.infinispan.client.hotrod.impl.operations.RetryOnFailureOperation
 
TransportFactory - Interface in org.infinispan.client.hotrod.impl.transport
Transport factory for building and managing Transport objects.
TransportFactory - Class in org.infinispan.factories
Factory for Transport implementations
TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
 
transportFactory(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
transportFactory(Class<? extends TransportFactory>) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
transportFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
transportFactory(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
transportFactory(Class<? extends TransportFactory>) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
transportFactory(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Controls which transport to use.
transportFactory(Class<? extends TransportFactory>) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Controls which transport to use.
TransportObjectFactory - Class in org.infinispan.client.hotrod.impl.transport.tcp
 
TransportObjectFactory(Codec, TcpTransportFactory, AtomicInteger, boolean) - Constructor for class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
 
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
 
TRUST_STORE_FILE_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
TRUST_STORE_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
trustStoreFileName() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
trustStoreFileName(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Specifies the filename of a truststore to use to create the SSLContext You also need to specify a SslConfigurationBuilder.trustStorePassword(char[]).
trustStorePassword() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
trustStorePassword(char[]) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Specifies the password needed to open the truststore You also need to specify a SslConfigurationBuilder.trustStoreFileName(String) Alternatively specify an array of #trustManagers(TrustManager[])
tryAcquire(int) - Method in class org.infinispan.util.concurrent.locks.OwnableReentrantLock
 
tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
tryAdvance(EquivalentConcurrentHashMapV8.Action<? super T>) - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.ConcurrentHashMapSpliterator
If an element remains, applies the action and returns true.
tryComplete() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.CountedCompleter
If the pending count is nonzero, decrements the count; otherwise invokes CountedCompleter.onCompletion(org.infinispan.commons.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 class org.infinispan.lucene.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite(String) - Method in class org.infinispan.query.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite(String) - Method in interface org.infinispan.util.logging.Log
 
tryingToBringOnlineNonexistentSite(String) - Method in class org.infinispan.util.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite$str() - Method in class org.infinispan.query.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
trySkipL1Update() - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
Attempts to mark the L1 update to only retrieve the value and not to actually update the L1 cache.
trySplit() - Method in interface org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8.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.commons.util.concurrent.jdk8backported.ForkJoinTask
Tries to unschedule this task for execution.
TwoWayKey2StringMapper - Interface in org.infinispan.persistence.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.AbstractEnlistmentAdapter
 
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.
txMarker(byte) - Method in class org.infinispan.client.hotrod.impl.protocol.HeaderParams
 
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
 
TypeConverter<K,V,KT,VT> - Interface in org.infinispan.compat
A type converter for cached keys and values.
TypeConverterInterceptor - Class in org.infinispan.interceptors.compat
An interceptor that applies type conversion to the data stored in the cache.
TypeConverterInterceptor(Marshaller) - Constructor for class org.infinispan.interceptors.compat.TypeConverterInterceptor
 
TypedProperties - Class in org.infinispan.client.hotrod.impl
Type-aware properties.
TypedProperties(Properties) - Constructor for class org.infinispan.client.hotrod.impl.TypedProperties
Copy constructor
TypedProperties() - Constructor for class org.infinispan.client.hotrod.impl.TypedProperties
Default constructor that returns an empty instance
TypedProperties - Class in org.infinispan.commons.util
Type-aware properties.
TypedProperties(Properties) - Constructor for class org.infinispan.commons.util.TypedProperties
Copy constructor
TypedProperties() - Constructor for class org.infinispan.commons.util.TypedProperties
Default constructor that returns an empty instance
TypedProperties - Class in org.infinispan.util
Deprecated.
TypedProperties() - Constructor for class org.infinispan.util.TypedProperties
Deprecated.
 
TypedProperties(Properties) - Constructor for class org.infinispan.util.TypedProperties
Deprecated.
 
typeIsUsingDefaultTransformer(Class<?>) - Method in interface org.infinispan.query.logging.Log
 
typeIsUsingDefaultTransformer(Class) - Method in class org.infinispan.query.logging.Log_$logger
 
typeIsUsingDefaultTransformer$str() - Method in class org.infinispan.query.logging.Log_$logger
 

U

unableToAcquireLockToPurgeStore() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToAcquireLockToPurgeStore() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToAcquireLockToPurgeStore() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToAcquireLockToPurgeStore() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToAcquireLockToPurgeStore() - Method in interface org.infinispan.util.logging.Log
 
unableToAcquireLockToPurgeStore() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToAcquireLockToPurgeStore$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToAcquireLockToPurgeStore$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToAcquireLockToPurgeStore$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToAcquireLockToPurgeStore$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToAcquireLockToPurgeStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToApplyPrepare(PrepareCommand, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToApplyPrepare$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToApplyPrepare$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToApplyPrepare$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToApplyPrepare$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToApplyPrepare$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCommitTransaction(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
unableToCommitTransaction(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCommitTransaction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in interface org.infinispan.commons.logging.Log
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToBoolean(String, boolean) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToConvertStringPropertyToBoolean$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in interface org.infinispan.commons.logging.Log
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToConvertStringPropertyToInt(String, int) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToInt(String, int) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToConvertStringPropertyToInt$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in interface org.infinispan.commons.logging.Log
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToConvertStringPropertyToLong(String, long) - Method in interface org.infinispan.util.logging.Log
 
unableToConvertStringPropertyToLong(String, long) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToConvertStringPropertyToLong$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in interface org.infinispan.util.logging.Log
 
unableToCopyEntryForUpdate(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCopyEntryForUpdate$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCopyEntryForUpdate$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToCopyEntryForUpdate$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToCopyEntryForUpdate$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToCopyEntryForUpdate$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCreateDirectory(String) - Method in interface org.infinispan.lucene.logging.Log
 
unableToCreateDirectory(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCreateDirectory$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToCreateInterceptor(Class, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCreateInterceptor$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToCreateInterceptor$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToCreateInterceptor$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToCreateInterceptor$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToCreateInterceptor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvalidateTransport(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
unableToInvalidateTransport(SocketAddress) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToInvalidateTransport$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeGetterOnConfiguration(Method, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToInvokeGetterOnConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeListenerMethod$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToInvokeListenerMethod$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToInvokeListenerMethod$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToInvokeListenerMethod$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToInvokeListenerMethod$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLoadClass(String, String, Throwable) - Method in interface org.infinispan.commons.logging.Log
 
unableToLoadClass(String, String, Throwable) - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToLoadClass(String, String, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToLoadClass(String, String, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToLoadClass(String, String, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToLoadClass(String, String, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToLoadClass(String, String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToLoadClass(String, String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLoadClass$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToLoadClass$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToLoadClass$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToLoadClass$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToLoadClass$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToLoadClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLoadFromCacheLoader(Object, PersistenceException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToLoadFromCacheLoader(Object, PersistenceException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToLoadFromCacheLoader(Object, PersistenceException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToLoadFromCacheLoader(Object, PersistenceException) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToLoadFromCacheLoader(Object, PersistenceException) - Method in interface org.infinispan.util.logging.Log
 
unableToLoadFromCacheLoader(Object, PersistenceException) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLoadFromCacheLoader$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToLoadFromCacheLoader$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToLoadFromCacheLoader$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToLoadFromCacheLoader$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToLoadFromCacheLoader$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in interface org.infinispan.util.logging.Log
 
unableToLockToInvalidate(Object, Address) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLockToInvalidate$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToLockToInvalidate$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToLockToInvalidate$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToLockToInvalidate$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToLockToInvalidate$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToPassivateEntry(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToPassivateEntry$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToPassivateEntry$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToPassivateEntry$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToPassivateEntry$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToPassivateEntry$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in interface org.infinispan.util.logging.Log
 
unableToProcessAsyncModifications(int) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToProcessAsyncModifications$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToProcessAsyncModifications$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToProcessAsyncModifications$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToProcessAsyncModifications$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToProcessAsyncModifications$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToReadVersionId() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToReadVersionId() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToReadVersionId() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToReadVersionId() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToReadVersionId() - Method in interface org.infinispan.util.logging.Log
 
unableToReadVersionId() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToReadVersionId$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToReadVersionId$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToReadVersionId$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToReadVersionId$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToReadVersionId$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterCacheManagerMBeans() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRegisterMBeans(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRegisterMBeans() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRegisterMBeans(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRegisterMBeans() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRegisterMBeans(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRegisterMBeans() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRegisterMBeans(String) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRegisterMBeans() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterMBeans(String) - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterMBeans() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans0$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRegisterMBeans0$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRegisterMBeans0$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRegisterMBeans0$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRegisterMBeans0$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans1$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRegisterMBeans1$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRegisterMBeans1$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRegisterMBeans1$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRegisterMBeans1$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRemoveEntryAfterActivation$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRemoveEntryAfterActivation$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRemoveEntryAfterActivation$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRemoveEntryAfterActivation$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRemoveEntryAfterActivation$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(String, String, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(String, String, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(String, String, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(String, String, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToResetGlobalComponentRegistryAfterRestart(String, String, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToResetGlobalComponentRegistryAfterRestart(String, String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart0$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart0$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart0$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart0$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart0$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart2$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart2$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart2$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart2$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToResetGlobalComponentRegistryAfterRestart2$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackGlobalTx$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToRollbackGlobalTx$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToRollbackGlobalTx$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToRollbackGlobalTx$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToRollbackGlobalTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToSetValue(Exception) - Method in interface org.infinispan.commons.logging.Log
 
unableToSetValue(Exception) - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToSetValue(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToSetValue(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToSetValue(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToSetValue(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToSetValue(Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToSetValue(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToSetValue$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToSetValue$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToSetValue$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToSetValue$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToSetValue$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToSetValue$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToStartTransaction(Exception) - Method in interface org.infinispan.lucene.logging.Log
 
unableToStartTransaction(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToStartTransaction$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUnlockRebalancedKeys(GlobalTransaction, List, Address, Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUnlockRebalancedKeys(GlobalTransaction, List, Address, Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToUnlockRebalancedKeys(GlobalTransaction, List, Address, Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToUnlockRebalancedKeys(GlobalTransaction, List, Address, Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToUnlockRebalancedKeys(GlobalTransaction, List<Object>, Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToUnlockRebalancedKeys(GlobalTransaction, List, Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUnlockRebalancedKeys$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUnlockRebalancedKeys$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToUnlockRebalancedKeys$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToUnlockRebalancedKeys$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToUnlockRebalancedKeys$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in interface org.infinispan.util.logging.Log
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUnwrap(Object, Class<?>) - Method in interface org.infinispan.commons.logging.Log
 
unableToUnwrap(Object, Class) - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToUnwrap$str() - Method in class org.infinispan.commons.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in class org.infinispan.query.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in interface org.infinispan.util.logging.Log
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unbindingDummyTmFailed(NamingException) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unbindingDummyTmFailed(NamingException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unbindingDummyTmFailed(NamingException) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unbindingDummyTmFailed(NamingException) - Method in class org.infinispan.query.logging.Log_$logger
 
unbindingDummyTmFailed(NamingException) - Method in interface org.infinispan.util.logging.Log
 
unbindingDummyTmFailed(NamingException) - Method in class org.infinispan.util.logging.Log_$logger
 
unbindingDummyTmFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unbindingDummyTmFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unbindingDummyTmFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unbindingDummyTmFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unbindingDummyTmFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unblock() - Method in class org.infinispan.factories.TestDelayFactory.Control
 
unblock() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
unBlock() - Method in interface org.infinispan.transaction.totalorder.TotalOrderLatch
Unblocks this synchronization block
unBlock() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 
UNBOUNDED - Static variable in interface org.infinispan.context.InvocationContextFactory
To be used when building InvocationContext with InvocationContextFactory.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, Equivalence, Equivalence) - Static method in class org.infinispan.container.DefaultDataContainer
 
unBoundedDataContainer(int) - Static method in class org.infinispan.container.DefaultDataContainer
 
unboxKey(KT) - Method in interface org.infinispan.compat.TypeConverter
Convert back an instance of the target key type into an instance of the cached key type.
unboxValue(VT) - Method in interface org.infinispan.compat.TypeConverter
Convert back an instance of the target value type into an instance of the cached value type.
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
 
undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
undelete(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
undelete(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
If the entry is marked as removed and doUndelete==true then the "valid" flag is set to true and "removed" flag is set to false.
undelete(boolean) - Method in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
undelete(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
unexpectedAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an unexpected XML attribute.
unexpectedClassNotFoundException(ClassNotFoundException) - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
unexpectedClassNotFoundException(ClassNotFoundException) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedClassNotFoundException$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
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 class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorFromResourceManager(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorFromResourceManager(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorFromResourceManager(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorFromResourceManager(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorFromResourceManager(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorFromResourceManager$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorFromResourceManager$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorFromResourceManager$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorFromResourceManager$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorFromResourceManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorInAsyncProcessor(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorInAsyncProcessor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorReplicating(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorReplicating$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedErrorReplicating$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedErrorReplicating$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedErrorReplicating$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedErrorReplicating$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in interface org.infinispan.util.logging.Log
 
unexpectedInitialVersion(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedInitialVersion$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedInitialVersion$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedInitialVersion$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedInitialVersion$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedInitialVersion$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedResponse(String, String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedResponse(String, String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedResponse(String, String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedResponse(String, String) - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedResponse(String, String) - Method in interface org.infinispan.util.logging.Log
 
unexpectedResponse(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedResponse$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unexpectedResponse$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unexpectedResponse$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unexpectedResponse$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unexpectedResponse$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in class org.infinispan.query.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in interface org.infinispan.util.logging.Log
 
unfinishedTransactionsRemain(int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
unfinishedTransactionsRemain$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unfinishedTransactionsRemain$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unfinishedTransactionsRemain$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unfinishedTransactionsRemain$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unfinishedTransactionsRemain$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
UNKNOWN_COMMAND_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
UNKNOWN_VERSION_STATUS - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
unknownExternalizerReaderIndex(int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unknownExternalizerReaderIndex(int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unknownExternalizerReaderIndex(int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unknownExternalizerReaderIndex(int) - Method in class org.infinispan.query.logging.Log_$logger
 
unknownExternalizerReaderIndex(int) - Method in interface org.infinispan.util.logging.Log
 
unknownExternalizerReaderIndex(int) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownExternalizerReaderIndex$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unknownExternalizerReaderIndex$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unknownExternalizerReaderIndex$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unknownExternalizerReaderIndex$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unknownExternalizerReaderIndex$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unknownMigrator(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unknownMigrator(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unknownMigrator(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unknownMigrator(String) - Method in class org.infinispan.query.logging.Log_$logger
 
unknownMigrator(String) - Method in interface org.infinispan.util.logging.Log
 
unknownMigrator(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownMigrator$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unknownMigrator$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unknownMigrator$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unknownMigrator$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unknownMigrator$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection) - Method in class org.infinispan.query.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection<Response>) - Method in interface org.infinispan.util.logging.Log
 
unknownResponsesFromRemoteCache(Collection) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownResponsesFromRemoteCache$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unknownResponsesFromRemoteCache$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unknownResponsesFromRemoteCache$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unknownResponsesFromRemoteCache$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unknownResponsesFromRemoteCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unlock(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
unlock(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
unlock(Integer) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
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
 
unmanagedConnectionFactory() - Method in interface org.infinispan.persistence.jdbc.logging.Log
 
unmanagedConnectionFactory() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unmanagedConnectionFactory$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unmarshall(StreamingMarshaller, InputStream) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
 
unmarshallMap(Map<Object, Object>, ObjectInput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
 
unprocessedTxLogEntries(int) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unprocessedTxLogEntries(int) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unprocessedTxLogEntries(int) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unprocessedTxLogEntries(int) - Method in class org.infinispan.query.logging.Log_$logger
 
unprocessedTxLogEntries(int) - Method in interface org.infinispan.util.logging.Log
 
unprocessedTxLogEntries(int) - Method in class org.infinispan.util.logging.Log_$logger
 
unprocessedTxLogEntries$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unprocessedTxLogEntries$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unprocessedTxLogEntries$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unprocessedTxLogEntries$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unprocessedTxLogEntries$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unquote(String) - Static method in class org.infinispan.cli.connection.jmx.JMXConnection
 
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
 
unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in interface org.infinispan.distribution.L1Manager
Unregister the given write synchronizer if present.
unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in class org.infinispan.distribution.L1ManagerImpl
 
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() - 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.commons.io
Helper to read and write unsigned numerics
UnsignedNumeric() - Constructor for class org.infinispan.commons.io.UnsignedNumeric
 
unstartedRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.logging.Log
 
unstartedRemoteCacheManager() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
unstartedRemoteCacheManager$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
UNSUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.marshall.core.Ids
 
UnsuccessfulResponse - Class in org.infinispan.remoting.responses
An unsuccessful response
UnsuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
UnsupportedKeyTypeException - Exception in org.infinispan.persistence.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.persistence.keymappers.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(String, Throwable) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
 
UnsupportedKeyTypeException(Throwable) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in class org.infinispan.lucene.logging.Log_$logger
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in class org.infinispan.query.logging.Log_$logger
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in interface org.infinispan.util.logging.Log
 
unsupportedTransactionConfiguration(boolean, boolean, boolean) - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedTransactionConfiguration$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
unsupportedTransactionConfiguration$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
unsupportedTransactionConfiguration$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unsupportedTransactionConfiguration$str() - Method in class org.infinispan.query.logging.Log_$logger
 
unsupportedTransactionConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedValueFormat(String) - Method in interface org.infinispan.persistence.remote.logging.Log
 
unsupportedValueFormat(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
unsupportedValueFormat$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
UNSURE_RESPONSE - Static variable in interface org.infinispan.marshall.core.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
 
unwrap(Object, Class<T>) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
update(InternalCacheEntry, Metadata) - Method in interface org.infinispan.container.InternalEntryFactory
TODO: Adjust javadoc Updates an existing InternalCacheEntry with new metadata.
update(InternalCacheEntry, Metadata) - Method in class org.infinispan.container.InternalEntryFactoryImpl
 
UPDATE_INDEX - Static variable in interface org.infinispan.query.impl.ModuleCommandIds
 
updateBucket(Bucket) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
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
 
updateHashFunction(Map<SocketAddress, Set<Integer>>, int, short, int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
updateHashFunction(Map<SocketAddress, Set<Integer>>, int, short, int) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
updateIndexes(Object, Object, TransactionContext) - Method in class org.infinispan.query.backend.QueryInterceptor
 
updateKnownTypesIfNeeded(Object) - Method in class org.infinispan.query.backend.QueryInterceptor
 
updateMembers(CH, List<Address>, Map<Address, Float>) - 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>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.DefaultConsistentHashFactory
Leavers are removed and segments without owners are assigned new owners.
updateMembers(ReplicatedConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.ReplicatedConsistentHashFactory
 
updateMembers(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.SyncConsistentHashFactory
 
updateOnCommunicationFailure(long) - Method in class org.infinispan.xsite.OfflineStatus
 
Updater(boolean) - Constructor for class org.infinispan.interceptors.CacheWriterInterceptor.Updater
 
updateRebalanceMembersList() - Method in class org.infinispan.topology.ClusterCacheStatus
updateServers(Collection<SocketAddress>) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransportFactory
 
updateServers(Collection<SocketAddress>) - Method in interface org.infinispan.client.hotrod.impl.transport.TransportFactory
 
updateStatusFromRemoteResponse(Object) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
 
updateStatusFromRemoteResponse(Object) - Method in class org.infinispan.commands.write.ClearCommand
 
updateStatusFromRemoteResponse(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
updateStatusFromRemoteResponse(Object) - Method in class org.infinispan.commands.write.PutMapCommand
 
updateStatusFromRemoteResponse(Object) - Method in class org.infinispan.commands.write.RemoveCommand
 
updateStatusFromRemoteResponse(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
updateStatusFromRemoteResponse(Object) - Method in interface org.infinispan.commands.write.WriteCommand
Used for conditional commands, to update the status of the command on the originator based on the result of its execution on the primary owner.
Upgrade - Class in org.infinispan.cli.commands.server
 
Upgrade() - Constructor for class org.infinispan.cli.commands.server.Upgrade
 
upgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
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.
USE_SSL - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
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() - 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() - 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.
username - Variable in class org.infinispan.cli.connection.jmx.AbstractJMXUrl
 
username() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
 
username(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
username() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
 
username(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
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.
useSynchronization() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
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.PersistenceConfiguration
 
usingBatchModeTransactionManager() - Method in class org.infinispan.lucene.logging.Log_$logger
 
usingBatchModeTransactionManager() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
usingBatchModeTransactionManager() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
usingBatchModeTransactionManager() - Method in class org.infinispan.query.logging.Log_$logger
 
usingBatchModeTransactionManager() - Method in interface org.infinispan.util.logging.Log
 
usingBatchModeTransactionManager() - Method in class org.infinispan.util.logging.Log_$logger
 
usingBatchModeTransactionManager$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
usingBatchModeTransactionManager$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
usingBatchModeTransactionManager$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
usingBatchModeTransactionManager$str() - Method in class org.infinispan.query.logging.Log_$logger
 
usingBatchModeTransactionManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
usingStores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
Util - Class in org.infinispan.commons.util
General utility methods used throughout the Infinispan code base.
Util - Class in org.infinispan.util
Deprecated.
Use the new org.infinispan.commons.util.Util
Utils - Class in org.infinispan.cli.util
 
Utils() - Constructor for class org.infinispan.cli.util.Utils
 

V

validate() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
validate() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
 
validate() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
validate() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
validate() - Method in interface org.infinispan.commons.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.ClusteringConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
 
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.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.LockingConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
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
 
validate() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcBinaryStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcMixedStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
validate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
validateAndAddListenerInvocation(Object, KeyFilter, ClassLoader) - Method in class org.infinispan.notifications.AbstractListenerImpl
Loops through all valid methods on the object passed in, and caches the relevant methods as AbstractListenerImpl.ListenerInvocation for invocation by reflection.
validateObject(SocketAddress, TcpTransport) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TransportObjectFactory
This will be called by the test thread when testWhileIdle==true.
ValidResponse - Class in org.infinispan.remoting.responses
A valid response
ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
 
value - Variable in class org.infinispan.client.hotrod.impl.operations.AbstractKeyValueOperation
 
value - Variable in class org.infinispan.commands.write.RemoveCommand
When not null, value indicates that the entry should only be removed if the key is mapped to this value.
value - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
value - Variable in class org.infinispan.container.entries.ImmortalCacheEntry
 
value - Variable in class org.infinispan.container.entries.ImmortalCacheValue
 
value - Variable in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
value - Variable in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
value - Variable in class org.infinispan.container.entries.MortalCacheEntry
 
value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
value - Variable in class org.infinispan.container.entries.TransientCacheEntry
 
value - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
VALUE - Static variable in interface org.infinispan.query.ProjectionConstants
 
VALUE_SIZE_ESTIMATE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
valueEquivalence() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
 
valueEquivalence(Equivalence<V>) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Set the Equivalence instance to use to compare values stored in data container.
valueMatcher - Variable in class org.infinispan.commands.write.RemoveCommand
 
ValueMatcher - Enum in org.infinispan.commands.write
A policy for determining if a write command should be executed based on the current value in the cache.
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.cli.shell.Color
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.cli.shell.ShellMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.impl.operations.PingOperation.PingResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.commands.write.ValueMatcher
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
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.InterceptorConfiguration.Position
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.VersioningScheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.global.ShutdownHookBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Element
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.ParsedCacheMode
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.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.persistence.cli.configuration.Attribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.cli.configuration.Element
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.configuration.Attribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.configuration.Element
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.DatabaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.modifications.Modification.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.remote.configuration.Attribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.remote.configuration.Element
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.query.dsl.SortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.query.FetchOptions.FetchMode
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.TransactionProtocol
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.cli.shell.Color
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.cli.shell.ShellMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.client.hotrod.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.client.hotrod.impl.operations.PingOperation.PingResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
values() - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
values() - Static method in enum org.infinispan.commands.write.ValueMatcher
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
 
Values() - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap.Values
 
values() - Static method in enum org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.infinispan.commons.util.AbstractMap
 
values() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Returns a Collection view of the values contained in this map.
values() - Method in class org.infinispan.commons.util.concurrent.jdk8backported.EquivalentConcurrentHashMapV8
Returns a Collection view of the values contained in this map.
values() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
Values() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.Values
 
values() - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap
 
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.InterceptorConfiguration.Position
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.cache.VersioningScheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.global.ShutdownHookBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.Attribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.Element
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.ParsedCacheMode
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.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.persistence.cli.configuration.Attribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.cli.configuration.Element
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.jdbc.configuration.Attribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.jdbc.configuration.Element
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.jdbc.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.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.persistence.remote.configuration.Attribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.remote.configuration.Element
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.query.clustered.ClusteredQueryCommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.query.dsl.SortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.query.FetchOptions.FetchMode
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.TransactionProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.util.concurrent.BoundedConcurrentHashMap.Eviction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.util.concurrent.BoundedConcurrentHashMap
Returns a Collection view of the values contained in this map.
values() - Static method in enum org.infinispan.util.concurrent.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - 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, TimeService, Set<Flag>) - Constructor for class org.infinispan.commands.read.ValuesCommand
 
ValuesCommand.ExpiredFilteredValues - Class in org.infinispan.commands.read
 
valueSizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
valueSizeEstimate() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
valueSizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
valueSizeEstimate(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
This hint allows sizing of byte buffers when serializing and deserializing values, to minimize array resizing.
valueSizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
valueSizeEstimate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
valueSizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
valueSizeEstimate(int) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
This hint allows sizing of byte buffers when serializing and deserializing values, to minimize array resizing.
Version - Class in org.infinispan.cli.commands.server
 
Version() - Constructor for class org.infinispan.cli.commands.server.Version
 
version(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
version(String) - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
Version - Class in org.infinispan.client.hotrod
Defines client and protocol version.
Version() - Constructor for class org.infinispan.client.hotrod.Version
 
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 - Static variable in class org.infinispan.lucene.impl.LuceneVersionDetector
 
version(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
version - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
version(EntryVersion) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
version() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
version() - Method in class org.infinispan.metadata.InternalMetadataImpl
 
version(EntryVersion) - Method in interface org.infinispan.metadata.Metadata.Builder
Set version.
version() - Method in interface org.infinispan.metadata.Metadata
Returns the version of the cache entry with which this metadata object is associated.
version(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
version(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
version(String) - Method in class org.infinispan.query.logging.Log_$logger
 
version(String) - Method in interface org.infinispan.util.logging.Log
 
version(String) - Method in class org.infinispan.util.logging.Log_$logger
 
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$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
version$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
version$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
version$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
version$str() - Method in class org.infinispan.query.logging.Log_$logger
 
version$str() - Method in class org.infinispan.util.logging.Log_$logger
 
VERSION_10 - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
VERSION_11 - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
VERSION_12 - Static variable in interface org.infinispan.client.hotrod.impl.protocol.HotRodConstants
 
VERSION_ID - Static variable in class org.infinispan.Version
 
VersionAwareMarshaller - Class in org.infinispan.marshall.core
A delegate to various other marshallers like JBossMarshaller.
VersionAwareMarshaller() - Constructor for class org.infinispan.marshall.core.VersionAwareMarshaller
 
VersionAwareMarshaller - Class in org.infinispan.marshall
Deprecated.
VersionAwareMarshaller() - Constructor for class org.infinispan.marshall.VersionAwareMarshaller
Deprecated.
 
Versioned - Interface in org.infinispan.container.entries.versioned
An interface that marks the ability to handle versions
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
 
VersionedOperationResponse - Class in org.infinispan.client.hotrod.impl
 
VersionedOperationResponse(byte[], VersionedOperationResponse.RspCode) - Constructor for class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
VersionedOperationResponse.RspCode - Enum in org.infinispan.client.hotrod.impl
 
VersionedPrepareCommand - Class in org.infinispan.commands.tx
Same as PrepareCommand except that the transaction originator makes evident the versions of entries touched and stored in a transaction context so that accurate write skew checks may be performed by the lock owner(s).
VersionedPrepareCommand() - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedPrepareCommand(String, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedPrepareCommand(String) - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedValue<V> - Interface in org.infinispan.client.hotrod
Besides the key and value, also contains an version.
VersionedValueImpl<V> - Class in org.infinispan.client.hotrod.impl
 
VersionedValueImpl(long, V) - Constructor for class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
VersionGenerator - Interface in org.infinispan.container.versioning
Generates versions
versionGenerator - Variable in class org.infinispan.interceptors.VersionedEntryWrappingInterceptor
 
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
Version generator component factory.
VersioningMetaFactory() - Constructor for class org.infinispan.factories.VersioningMetaFactory
 
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.persistence.support.SingletonCacheWriter.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
 
visit(FileListCacheKey) - Method in interface org.infinispan.lucene.KeyVisitor
 
visit(ChunkCacheKey) - Method in interface org.infinispan.lucene.KeyVisitor
 
visit(FileCacheKey) - Method in interface org.infinispan.lucene.KeyVisitor
 
visit(FileReadLockKey) - Method in interface org.infinispan.lucene.KeyVisitor
 
visit(BaseQueryBuilder<T>) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(AndCondition) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(OrCondition) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(NotCondition) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(EqOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(GtOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(GteOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(LtOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(LteOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(BetweenOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(LikeOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(IsNullOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(InOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(ContainsOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(ContainsAllOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(ContainsAnyOperator) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
visit(AttributeCondition) - Method in class org.infinispan.query.dsl.impl.JPAQueryGenerator
 
VisitableCommand - Interface in org.infinispan.commands
A type of command that can accept Visitors, such as CommandInterceptors.
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.CacheWriterInterceptor.Updater
 
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
 
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.CacheWriterInterceptor.Updater
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
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.TxInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
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
 
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.CacheWriterInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.CallInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
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.totalorder.TotalOrderDistributionInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
 
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
 
visitDataWriteCommand(InvocationContext, DataWriteCommand, boolean) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
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.CacheLoaderInterceptor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
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.AbstractLockingInterceptor
 
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
 
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.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.compat.BaseTypeConverterInterceptor
 
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.TxInterceptor
 
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.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.distribution.L1NonTxInterceptor
 
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.CacheLoaderInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
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.totalorder.TotalOrderInterceptor
 
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
 
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.CacheWriterInterceptor
 
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.distribution.L1LastChanceInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
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.totalorder.TotalOrderInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
 
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.query.backend.QueryInterceptor
In case of a remotely originating transactions we don't have a chance to visit the single commands but receive this "batch".
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.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.CacheWriterInterceptor.Updater
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
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.AbstractLockingInterceptor
 
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.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
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.CacheWriterInterceptor.Updater
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
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.TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
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
 
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.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.CacheWriterInterceptor.Updater
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
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.TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
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.base.PrePostProcessingCommandInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheMgmtInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor.Updater
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.CacheWriterInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.compat.BaseTypeConverterInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DeadlockDetectingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DistCacheWriterInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
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.TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.query.backend.QueryInterceptor
 
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.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.totalorder.TotalOrderDistributionInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
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
 
visitSingleStore(InvocationContext, FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.CacheWriterInterceptor.Updater
 
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
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.CacheLoaderInterceptor
 
visitToken(DetailAST) - Method in class org.infinispan.checkstyle.checks.regexp.IllegalImport
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in interface org.infinispan.commands.Visitor
 
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.CacheLoaderInterceptor
 
visitValuesCommand(InvocationContext, ValuesCommand) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 

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 class org.infinispan.lucene.logging.Log_$logger
 
waitForCacheToStart(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
waitForCacheToStart(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
waitForCacheToStart(String) - Method in class org.infinispan.query.logging.Log_$logger
 
waitForCacheToStart(String) - Method in interface org.infinispan.util.logging.Log
 
waitForCacheToStart(String) - Method in class org.infinispan.util.logging.Log_$logger
 
waitForCacheToStart$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
waitForCacheToStart$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
waitForCacheToStart$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
waitForCacheToStart$str() - Method in class org.infinispan.query.logging.Log_$logger
 
waitForCacheToStart$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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, long, TimeUnit) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
waitForTopology(int, long, TimeUnit) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
waitForTransactionData(int, long, TimeUnit) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
waitForTransactionData(int, long, TimeUnit) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
waitingForWorkerThreadsFailed(CountDownLatch) - Method in class org.infinispan.lucene.logging.Log_$logger
 
waitingForWorkerThreadsFailed(CountDownLatch) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
waitingForWorkerThreadsFailed(CountDownLatch) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
waitingForWorkerThreadsFailed(CountDownLatch) - Method in class org.infinispan.query.logging.Log_$logger
 
waitingForWorkerThreadsFailed(CountDownLatch) - Method in interface org.infinispan.util.logging.Log
 
waitingForWorkerThreadsFailed(CountDownLatch) - Method in class org.infinispan.util.logging.Log_$logger
 
waitingForWorkerThreadsFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
waitingForWorkerThreadsFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
waitingForWorkerThreadsFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
waitingForWorkerThreadsFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
waitingForWorkerThreadsFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
waitUntilAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
waitUntilPrepared(boolean) - Method in class org.infinispan.transaction.TotalOrderRemoteTransactionState
Commit and rollback commands invokes this method and they are blocked here if the state is PREPARING
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.
wallClockTime() - Method in class org.infinispan.util.DefaultTimeService
 
wallClockTime() - Method in interface org.infinispan.util.TimeService
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in class org.infinispan.query.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in interface org.infinispan.util.logging.Log
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in class org.infinispan.util.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotCommitLocalTx$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnCouldNotCommitLocalTx$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnCouldNotCommitLocalTx$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnCouldNotCommitLocalTx$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnCouldNotCommitLocalTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotRollbackLocalTx$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnCouldNotRollbackLocalTx$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnCouldNotRollbackLocalTx$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnCouldNotRollbackLocalTx$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnCouldNotRollbackLocalTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in interface org.infinispan.util.logging.Log
 
warnExceptionRemovingRecovery(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
warnExceptionRemovingRecovery$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnExceptionRemovingRecovery$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnExceptionRemovingRecovery$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnExceptionRemovingRecovery$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnExceptionRemovingRecovery$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in class org.infinispan.query.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in interface org.infinispan.util.logging.Log
 
warnFifoStrategyIsDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
warnFifoStrategyIsDeprecated$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnFifoStrategyIsDeprecated$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnFifoStrategyIsDeprecated$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnFifoStrategyIsDeprecated$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnFifoStrategyIsDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in class org.infinispan.query.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in interface org.infinispan.util.logging.Log
 
warnGridFSMetadataCacheRequiresSync() - Method in class org.infinispan.util.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in class org.infinispan.query.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in interface org.infinispan.util.logging.Log
 
warnL1NotHavingReaperThread() - Method in class org.infinispan.util.logging.Log_$logger
 
warnL1NotHavingReaperThread$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnL1NotHavingReaperThread$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnL1NotHavingReaperThread$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnL1NotHavingReaperThread$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnL1NotHavingReaperThread$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel() - Method in class org.infinispan.query.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel() - Method in interface org.infinispan.util.logging.Log
 
warnStrictPeerToPeerWithInjectedChannel() - Method in class org.infinispan.util.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnStrictPeerToPeerWithInjectedChannel$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in class org.infinispan.query.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in interface org.infinispan.util.logging.Log
 
warnXsiteBackupFailed(String, String, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
warnXsiteBackupFailed$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
warnXsiteBackupFailed$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
warnXsiteBackupFailed$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
warnXsiteBackupFailed$str() - Method in class org.infinispan.query.logging.Log_$logger
 
warnXsiteBackupFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
WeakValueHashMap<K,V> - Class in org.infinispan.commons.util
This Map will remove entries when the value in the map has been cleaned from garbage collection
WeakValueHashMap(int, float) - Constructor for class org.infinispan.commons.util.WeakValueHashMap
Constructs a new, empty WeakValueHashMap with the given initial capacity and the given load factor.
WeakValueHashMap(int) - Constructor for class org.infinispan.commons.util.WeakValueHashMap
Constructs a new, empty WeakValueHashMap with the given initial capacity and the default load factor, which is 0.75.
WeakValueHashMap() - Constructor for class org.infinispan.commons.util.WeakValueHashMap
Constructs a new, empty WeakValueHashMap with the default initial capacity and the default load factor, which is 0.75.
WeakValueHashMap(Map<K, V>) - Constructor for class org.infinispan.commons.util.WeakValueHashMap
Constructs a new WeakValueHashMap with the same mappings as the specified Map.
WeakValueHashMap.ValueRef<K,V> - Interface in org.infinispan.commons.util
 
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.commons.util.ClassFinder
 
withAnnotationPresent(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ClassFinder
 
withAnnotationPresent(Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ClassFinder
 
withExecutorProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Set key/value properties to this executor factory configuration
withExecutorProperties(Properties) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Set key/value properties to this executor factory configuration
withFlags(Flag...) - Method in class org.infinispan.AbstractDelegatingAdvancedCache
 
withFlags(Flag...) - Method in interface org.infinispan.AdvancedCache
A method that adds flags to any API call.
withFlags(Flag...) - Method in class org.infinispan.CacheImpl
 
withFlags(Flag...) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
withFlags(Flag...) - Method in interface org.infinispan.client.hotrod.RemoteCache
Applies one or more Flags to the scope of a single invocation.
withFlags(Flag...) - Method in class org.infinispan.DecoratedCache
 
withGroupers(List<Grouper<?>>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Set the groupers to use
WithinThreadExecutor - Class in org.infinispan.util.concurrent
An executor that works within the current thread.
WithinThreadExecutor() - Constructor for class org.infinispan.util.concurrent.WithinThreadExecutor
 
WithinThreadExecutorFactory - Class in org.infinispan.executors
Executor factory that creates WithinThreadExecutor.
WithinThreadExecutorFactory() - Constructor for class org.infinispan.executors.WithinThreadExecutorFactory
 
withPoolProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Configures the connection pool parameter according to properties
withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
withProperties(Properties) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Configures this builder using the specified properties
withProperties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Properties passed to the cache store or loader
withProperties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
withProperties(Properties) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
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.IndexingConfigurationBuilder
The Query engine relies on properties for configuration.
withProperties(Properties) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Sets interceptor properties
withProperties(Properties) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
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
workListRemotedTo(Object, Address) - Method in interface org.infinispan.query.logging.Log
 
workListRemotedTo(Object, Address) - Method in class org.infinispan.query.logging.Log_$logger
 
workListRemotedTo$str() - Method in class org.infinispan.query.logging.Log_$logger
 
wouldLose(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
 
wrap(AdvancedCache<K, V>) - Method in interface org.infinispan.AbstractDelegatingAdvancedCache.AdvancedCacheWrapper
 
wrapEntriesForPrepare(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.EntryWrappingInterceptor
 
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, boolean) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for addition to cache.
wrapEntryForPut(InvocationContext, Object, InternalCacheEntry, boolean, FlagAffectedCommand, boolean) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForReading(InvocationContext, Object) - Method in interface org.infinispan.container.EntryFactory
Wraps an entry for reading.
wrapEntryForReading(InvocationContext, Object) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForRemove(InvocationContext, Object, boolean, boolean, boolean) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for removal.
wrapEntryForRemove(InvocationContext, Object, boolean, boolean, boolean) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapEntryForReplace(InvocationContext, ReplaceCommand) - Method in interface org.infinispan.container.EntryFactory
Used for wrapping a cache entry for replacement.
wrapEntryForReplace(InvocationContext, ReplaceCommand) - Method in class org.infinispan.container.EntryFactoryImpl
 
wrapMap(Map<Object, Object>, Set<MarshalledValue>, InvocationContext) - Method in class org.infinispan.interceptors.MarshalledValueInterceptor
 
wrapNativeDirectory(Directory) - Static method in class org.infinispan.lucene.cacheloader.ContractAdaptorFactory
 
wrappedEntry - Variable in class org.infinispan.container.entries.DeltaAwareCacheEntry
 
WritableGridFileChannel - Class in org.infinispan.io
 
write(byte[], int, int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
 
write(int) - Method in class org.infinispan.commons.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.commons.util.Base64.OutputStream
Calls Base64.OutputStream.write(int) repeatedly until len bytes are written.
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
Deprecated.
 
write(int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
 
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(MarshalledEntry) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.file.SingleFileStore
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.jdbc.binary.JdbcBinaryStore
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.jdbc.mixed.JdbcMixedStore
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.remote.RemoteStore
 
write(MarshalledEntry<K, V>) - Method in interface org.infinispan.persistence.spi.CacheWriter
Persists the entry to the storage.
write(MarshalledEntry) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
 
writeArray(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeArray(byte[]) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(short) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeByte(short) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(byte) - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
writeBytes(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeBytes(byte[]) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBytes(byte[], int, int) - Method in class org.infinispan.lucene.impl.InfinispanIndexOutput
 
writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
WriteCommand - Interface in org.infinispan.commands.write
A command that modifies the cache in some way
writeCommandHeader(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeCommandParameters(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeExternal(Object, ObjectOutput) - Method in class org.infinispan.commons.marshall.jboss.JBossExternalizerAdapter
 
writeExternal(ObjectOutput) - Method in class org.infinispan.commons.util.ImmutableListCopy
Format: - entry array size (int) - elements (Object)
writeExternal(ObjectOutput) - Method in class org.infinispan.io.GridFile.Metadata
 
writeExternal(ObjectOutput) - Method in class org.infinispan.marshall.core.MarshalledValue
 
writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeHeader(Transport, short) - Method in class org.infinispan.client.hotrod.impl.operations.HotRodOperation
 
writeHeader(Transport, HeaderParams) - Method in interface org.infinispan.client.hotrod.impl.protocol.Codec
Writes a request header with the given parameters to the transport and returns an updated header parameters.
writeHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
writeHeader(Transport, HeaderParams, byte) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec10
 
writeHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec11
 
writeHeader(Transport, HeaderParams) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec12
 
writeHeader(Transport, HeaderParams, byte) - Method in class org.infinispan.client.hotrod.impl.protocol.Codec12
 
writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeLong(long) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeLong(long) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeManagedAttributeAlreadyPresent(String) - Method in class org.infinispan.lucene.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent(String) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent(String) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent(String) - Method in class org.infinispan.query.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent(String) - Method in interface org.infinispan.util.logging.Log
 
writeManagedAttributeAlreadyPresent(String) - Method in class org.infinispan.util.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.query.logging.Log_$logger
 
writeManagedAttributeAlreadyPresent$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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, ByteBufferImpl) - Method in class org.infinispan.commons.io.ByteBufferImpl.Externalizer
 
writeObject(ObjectOutput, T) - Method in interface org.infinispan.commons.marshall.Externalizer
Write the object reference to the stream.
writeObject(ObjectOutput, T) - Method in class org.infinispan.commons.marshall.exts.NoStateExternalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
writeObject(ObjectOutput, List) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyList.EmptyListExternalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptyMap.EmptyMapExternalizer
 
writeObject(ObjectOutput, Set) - Method in class org.infinispan.commons.util.InfinispanCollections.EmptySet.EmptySetExternalizer
 
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, MetadataImmortalCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, MetadataImmortalCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
writeObject(ObjectOutput, MetadataMortalCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, MetadataMortalCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
writeObject(ObjectOutput, MetadataTransientCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
writeObject(ObjectOutput, MetadataTransientCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
writeObject(ObjectOutput, MetadataTransientMortalCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, MetadataTransientMortalCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.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, NumericVersion) - Method in class org.infinispan.container.versioning.NumericVersion.Externalizer
 
writeObject(ObjectOutput, SimpleClusteredVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.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, ChunkCacheKey) - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
 
writeObject(ObjectOutput, FileCacheKey) - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
 
writeObject(ObjectOutput, FileListCacheKey) - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
 
writeObject(ObjectOutput, FileMetadata) - Method in class org.infinispan.lucene.FileMetadata.Externalizer
 
writeObject(ObjectOutput, FileReadLockKey) - Method in class org.infinispan.lucene.FileReadLockKey.Externalizer
 
writeObject(ObjectOutput, MarshalledEntryImpl) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
writeObject(ObjectOutput, MarshalledValue) - Method in class org.infinispan.marshall.core.MarshalledValue.Externalizer
 
writeObject(ObjectOutput, T) - Method in interface org.infinispan.marshall.Externalizer
Deprecated.
Write the object reference to the stream.
writeObject(ObjectOutput, List[]) - Method in class org.infinispan.marshall.exts.ArrayExternalizers.ListArray
 
writeObject(ObjectOutput, CacheRpcCommand) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
writeObject(ObjectOutput, Set) - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
writeObject(ObjectOutput, List) - Method in class org.infinispan.marshall.exts.ListExternalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
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, T) - Method in class org.infinispan.marshall.LegacyAdvancedExternalizerAdapter
Deprecated.
 
writeObject(ObjectOutput, T) - Method in class org.infinispan.marshall.LegacyExternalizerAdapter
Deprecated.
 
writeObject(ObjectOutput, EmbeddedMetadata) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
writeObject(ObjectOutput, InternalMetadataImpl) - Method in class org.infinispan.metadata.InternalMetadataImpl.Externalizer
 
writeObject(ObjectOutput, ScopedKey) - Method in class org.infinispan.registry.ScopedKey.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, KeyValuePair) - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
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, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewException(String, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewException(String, Throwable, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewHelper - Class in org.infinispan.transaction
Encapsulates write skew logic in maintaining version maps, etc.
WriteSkewHelper() - Constructor for class org.infinispan.transaction.WriteSkewHelper
 
WriteSkewHelper.KeySpecificLogic - Interface in org.infinispan.transaction
 
writesToASingleKey() - Method in class org.infinispan.commands.tx.PrepareCommand
 
writeString(String) - Method in class org.infinispan.client.hotrod.impl.transport.AbstractTransport
 
writeString(String) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeTo(MessageMarshaller.ProtoStreamWriter, QueryRequest) - Method in class org.infinispan.query.remote.client.QueryRequestMarshaller
 
writeTo(MessageMarshaller.ProtoStreamWriter, QueryResponse) - Method in class org.infinispan.query.remote.client.QueryResponseMarshaller
 
writeTo(MessageMarshaller.ProtoStreamWriter, QueryRequest.SortCriteria) - Method in class org.infinispan.query.remote.client.SortCriteriaMarshaller
 
writeToAllStores(MarshalledEntry, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
writeToAllStores(MarshalledEntry, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
writeUnsignedInt(ObjectOutput, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedInt(OutputStream, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
writeUnsignedInt(ByteBuffer, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
writeUnsignedInt(byte[], int, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(ObjectOutput, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUnsignedLong(OutputStream, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
writeUnsignedLong(ByteBuffer, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
 
writeUnsignedLong(byte[], int, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
Writes an int in a variable-length format.
writeUTF(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeVInt(int) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeVInt(int) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
writeVLong(long) - Method in class org.infinispan.client.hotrod.impl.transport.tcp.TcpTransport
 
writeVLong(long) - Method in interface org.infinispan.client.hotrod.impl.transport.Transport
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.lucene.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.query.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup$str() - Method in class org.infinispan.lucene.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup$str() - Method in class org.infinispan.persistence.jdbc.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup$str() - Method in class org.infinispan.persistence.remote.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup$str() - Method in class org.infinispan.query.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup$str() - Method in class org.infinispan.util.logging.Log_$logger
 

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.core.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.core.Ids
 
XID_GLOBAL_TRANSACTION - Static variable in interface org.infinispan.marshall.core.Ids
 
XidExternalizer() - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
 
XmlConfigHelper - Class in org.infinispan.configuration.parsing
A simple XML utility class for reading configuration elements
XmlConfigHelper() - Constructor for class org.infinispan.configuration.parsing.XmlConfigHelper
 
XMLExtendedStreamReader - Interface in org.infinispan.configuration.parsing
An XML stream reader that can read nested <xs:any> content using a registered set of root elements.
xorSSLContext() - Method in interface org.infinispan.client.hotrod.logging.Log
 
xorSSLContext() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
xorSSLContext$str() - Method in class org.infinispan.client.hotrod.logging.Log_$logger
 
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 _ 
Skip navigation links

Copyright © 2016 JBoss, a division of Red Hat. All rights reserved.